diff options
| author | Robert Godfrey <rgodfrey@apache.org> | 2014-10-17 14:23:19 +0000 |
|---|---|---|
| committer | Robert Godfrey <rgodfrey@apache.org> | 2014-10-17 14:23:19 +0000 |
| commit | 28dbfe8d101dd14a95b1d75e799107bdaa6e18d0 (patch) | |
| tree | 279390c83b70fb7a41a4d42ee5cda92991140337 /qpid/java | |
| parent | 152b079dacea71ccd5efe7ef0458836d8aea8d2f (diff) | |
| download | qpid-python-28dbfe8d101dd14a95b1d75e799107bdaa6e18d0.tar.gz | |
QPID-6125 : [Java Broker] AMQP 0-8/9/9-1 protocol handler refactoring
git-svn-id: https://svn.apache.org/repos/asf/qpid/trunk@1632583 13f79535-47bb-0310-9956-ffa450edef68
Diffstat (limited to 'qpid/java')
549 files changed, 10406 insertions, 56793 deletions
diff --git a/qpid/java/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/upgrade/UpgradeFrom4To5.java b/qpid/java/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/upgrade/UpgradeFrom4To5.java index 3588b96e88..1d689090ae 100644 --- a/qpid/java/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/upgrade/UpgradeFrom4To5.java +++ b/qpid/java/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/upgrade/UpgradeFrom4To5.java @@ -30,7 +30,18 @@ import java.util.HashSet; import java.util.List; import java.util.Set; +import com.sleepycat.bind.tuple.ByteBinding; +import com.sleepycat.bind.tuple.LongBinding; +import com.sleepycat.bind.tuple.TupleBase; +import com.sleepycat.bind.tuple.TupleBinding; +import com.sleepycat.bind.tuple.TupleInput; +import com.sleepycat.bind.tuple.TupleOutput; +import com.sleepycat.je.Database; +import com.sleepycat.je.DatabaseEntry; +import com.sleepycat.je.Environment; +import com.sleepycat.je.Transaction; import org.apache.log4j.Logger; + import org.apache.qpid.common.AMQPFilterTypes; import org.apache.qpid.exchange.ExchangeDefaults; import org.apache.qpid.framing.AMQFrameDecodingException; @@ -38,25 +49,14 @@ import org.apache.qpid.framing.AMQProtocolVersionException; import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.ContentHeaderBody; import org.apache.qpid.framing.FieldTable; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.model.ConfiguredObject; import org.apache.qpid.server.protocol.v0_8.MessageMetaData; -import org.apache.qpid.server.store.StoreException; import org.apache.qpid.server.store.StorableMessageMetaData; +import org.apache.qpid.server.store.StoreException; import org.apache.qpid.server.store.berkeleydb.AMQShortStringEncoding; import org.apache.qpid.server.store.berkeleydb.FieldTableEncoding; -import com.sleepycat.bind.tuple.ByteBinding; -import com.sleepycat.bind.tuple.LongBinding; -import com.sleepycat.bind.tuple.TupleBase; -import com.sleepycat.bind.tuple.TupleBinding; -import com.sleepycat.bind.tuple.TupleInput; -import com.sleepycat.bind.tuple.TupleOutput; -import com.sleepycat.je.Database; -import com.sleepycat.je.DatabaseEntry; -import com.sleepycat.je.Environment; -import com.sleepycat.je.Transaction; - public class UpgradeFrom4To5 extends AbstractStoreUpgrade { private static final String OLD_DELIVERY_DB = "deliveryDb_v4"; @@ -662,34 +662,7 @@ public class UpgradeFrom4To5 extends AbstractStoreUpgrade final boolean mandatory = tupleInput.readBoolean(); final boolean immediate = tupleInput.readBoolean(); - return new MessagePublishInfo() - { - - public AMQShortString getExchange() - { - return exchange; - } - - public void setExchange(AMQShortString exchange) - { - - } - - public boolean isImmediate() - { - return immediate; - } - - public boolean isMandatory() - { - return mandatory; - } - - public AMQShortString getRoutingKey() - { - return routingKey; - } - }; + return new MessagePublishInfo(exchange, immediate, mandatory, routingKey); } diff --git a/qpid/java/bdbstore/src/test/java/org/apache/qpid/server/store/berkeleydb/BDBMessageStoreTest.java b/qpid/java/bdbstore/src/test/java/org/apache/qpid/server/store/berkeleydb/BDBMessageStoreTest.java index cff761b759..fb0c11f6e5 100644 --- a/qpid/java/bdbstore/src/test/java/org/apache/qpid/server/store/berkeleydb/BDBMessageStoreTest.java +++ b/qpid/java/bdbstore/src/test/java/org/apache/qpid/server/store/berkeleydb/BDBMessageStoreTest.java @@ -30,9 +30,7 @@ import java.util.Arrays; import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.BasicContentHeaderProperties; import org.apache.qpid.framing.ContentHeaderBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.ProtocolVersion; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.model.VirtualHost; import org.apache.qpid.server.protocol.v0_10.MessageMetaDataType_0_10; import org.apache.qpid.server.protocol.v0_10.MessageMetaData_0_10; @@ -234,44 +232,14 @@ public class BDBMessageStoreTest extends MessageStoreTestCase private MessagePublishInfo createPublishInfoBody_0_8() { - return new MessagePublishInfo() - { - public AMQShortString getExchange() - { - return new AMQShortString("exchange12345"); - } - - @Override - public void setExchange(AMQShortString exchange) - { - } - - @Override - public boolean isImmediate() - { - return false; - } - - @Override - public boolean isMandatory() - { - return true; - } - - @Override - public AMQShortString getRoutingKey() - { - return new AMQShortString("routingKey12345"); - } - }; + return new MessagePublishInfo(new AMQShortString("exchange12345"), false, true, + new AMQShortString("routingKey12345")); } private ContentHeaderBody createContentHeaderBody_0_8(BasicContentHeaderProperties props, int length) { - MethodRegistry methodRegistry = MethodRegistry.getMethodRegistry(ProtocolVersion.v0_9); - int classForBasic = methodRegistry.createBasicQosOkBody().getClazz(); - return new ContentHeaderBody(classForBasic, 1, props, length); + return new ContentHeaderBody(props, length); } private BasicContentHeaderProperties createContentHeaderProperties_0_8() diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQChannel.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQChannel.java index f6ef4256d0..5ca94891c1 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQChannel.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQChannel.java @@ -20,6 +20,8 @@ */ package org.apache.qpid.server.protocol.v0_8; +import static org.apache.qpid.transport.util.Functions.hex; + import java.nio.ByteBuffer; import java.security.AccessControlException; import java.security.PrivilegedAction; @@ -47,14 +49,8 @@ import org.apache.log4j.Logger; import org.apache.qpid.AMQConnectionException; import org.apache.qpid.AMQException; import org.apache.qpid.common.AMQPFilterTypes; -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.BasicContentHeaderProperties; -import org.apache.qpid.framing.ContentBody; -import org.apache.qpid.framing.ContentHeaderBody; -import org.apache.qpid.framing.FieldTable; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.exchange.ExchangeDefaults; +import org.apache.qpid.framing.*; import org.apache.qpid.protocol.AMQConstant; import org.apache.qpid.server.TransactionTimeoutHelper; import org.apache.qpid.server.TransactionTimeoutHelper.CloseAction; @@ -62,6 +58,7 @@ import org.apache.qpid.server.configuration.BrokerProperties; import org.apache.qpid.server.connection.SessionPrincipal; import org.apache.qpid.server.consumer.ConsumerImpl; import org.apache.qpid.server.consumer.ConsumerTarget; +import org.apache.qpid.server.exchange.ExchangeImpl; import org.apache.qpid.server.filter.AMQInvalidArgumentException; import org.apache.qpid.server.filter.FilterManager; import org.apache.qpid.server.filter.FilterManagerFactory; @@ -69,6 +66,7 @@ import org.apache.qpid.server.filter.Filterable; import org.apache.qpid.server.filter.MessageFilter; import org.apache.qpid.server.filter.SimpleFilterManager; import org.apache.qpid.server.flow.FlowCreditManager; +import org.apache.qpid.server.flow.MessageOnlyCreditManager; import org.apache.qpid.server.flow.Pre0_10CreditManager; import org.apache.qpid.server.logging.LogMessage; import org.apache.qpid.server.logging.LogSubject; @@ -85,13 +83,18 @@ import org.apache.qpid.server.model.ConfigurationChangeListener; import org.apache.qpid.server.model.ConfiguredObject; import org.apache.qpid.server.model.Consumer; import org.apache.qpid.server.model.Exchange; +import org.apache.qpid.server.model.ExclusivityPolicy; +import org.apache.qpid.server.model.LifetimePolicy; +import org.apache.qpid.server.model.NoFactoryForTypeException; +import org.apache.qpid.server.model.Queue; import org.apache.qpid.server.model.Session; import org.apache.qpid.server.model.State; +import org.apache.qpid.server.model.UnknownConfiguredObjectException; import org.apache.qpid.server.protocol.AMQSessionModel; import org.apache.qpid.server.protocol.CapacityChecker; import org.apache.qpid.server.protocol.ConsumerListener; -import org.apache.qpid.server.protocol.v0_8.output.ProtocolOutputConverter; import org.apache.qpid.server.queue.AMQQueue; +import org.apache.qpid.server.queue.QueueArgumentsConverter; import org.apache.qpid.server.security.SecurityManager; import org.apache.qpid.server.store.MessageStore; import org.apache.qpid.server.store.StoreFuture; @@ -103,12 +106,18 @@ import org.apache.qpid.server.txn.LocalTransaction.ActivityTimeAccessor; import org.apache.qpid.server.txn.ServerTransaction; import org.apache.qpid.server.util.Action; import org.apache.qpid.server.util.ConnectionScopedRuntimeException; +import org.apache.qpid.server.virtualhost.ExchangeExistsException; +import org.apache.qpid.server.virtualhost.ExchangeIsAlternateException; +import org.apache.qpid.server.virtualhost.QueueExistsException; +import org.apache.qpid.server.virtualhost.RequiredExchangeException; +import org.apache.qpid.server.virtualhost.ReservedExchangeNameException; import org.apache.qpid.server.virtualhost.VirtualHostImpl; import org.apache.qpid.transport.TransportException; -public class AMQChannel<T extends AMQProtocolSession<T>> - implements AMQSessionModel<AMQChannel<T>,T>, - AsyncAutoCommitTransaction.FutureRecorder +public class AMQChannel + implements AMQSessionModel<AMQChannel, AMQProtocolEngine>, + AsyncAutoCommitTransaction.FutureRecorder, + ServerChannelMethodProcessor { public static final int DEFAULT_PREFETCH = 4096; @@ -159,7 +168,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> private final AtomicLong _txnRejects = new AtomicLong(0); private final AtomicLong _txnCount = new AtomicLong(0); - private final T _session; + private final AMQProtocolEngine _connection; private AtomicBoolean _closing = new AtomicBoolean(false); private final Set<Object> _blockingEntities = Collections.synchronizedSet(new HashSet<Object>()); @@ -181,8 +190,8 @@ public class AMQChannel<T extends AMQProtocolSession<T>> private final TransactionTimeoutHelper _transactionTimeoutHelper; private final UUID _id = UUID.randomUUID(); - private final List<Action<? super AMQChannel<T>>> _taskList = - new CopyOnWriteArrayList<Action<? super AMQChannel<T>>>(); + private final List<Action<? super AMQChannel>> _taskList = + new CopyOnWriteArrayList<Action<? super AMQChannel>>(); private final CapacityCheckAction _capacityCheckAction = new CapacityCheckAction(); @@ -194,15 +203,14 @@ public class AMQChannel<T extends AMQProtocolSession<T>> private Session<?> _modelObject; - public AMQChannel(T session, int channelId, final MessageStore messageStore) - throws AMQException + public AMQChannel(AMQProtocolEngine connection, int channelId, final MessageStore messageStore) { - _session = session; + _connection = connection; _channelId = channelId; - _subject = new Subject(false, session.getAuthorizedSubject().getPrincipals(), - session.getAuthorizedSubject().getPublicCredentials(), - session.getAuthorizedSubject().getPrivateCredentials()); + _subject = new Subject(false, connection.getAuthorizedSubject().getPrincipals(), + connection.getAuthorizedSubject().getPublicCredentials(), + connection.getAuthorizedSubject().getPrivateCredentials()); _subject.getPrincipals().add(new SessionPrincipal(this)); _logSubject = new ChannelLogSubject(this); @@ -211,7 +219,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> // by default the session is non-transactional _transaction = new AsyncAutoCommitTransaction(_messageStore, this); - _clientDeliveryMethod = session.createDeliveryMethod(_channelId); + _clientDeliveryMethod = connection.createDeliveryMethod(_channelId); _transactionTimeoutHelper = new TransactionTimeoutHelper(_logSubject, new CloseAction() { @@ -242,6 +250,52 @@ public class AMQChannel<T extends AMQProtocolSession<T>> } + private boolean performGet(final AMQQueue queue, + final boolean acks) + throws MessageSource.ExistingConsumerPreventsExclusive, + MessageSource.ExistingExclusiveConsumer, MessageSource.ConsumerAccessRefused + { + + final FlowCreditManager singleMessageCredit = new MessageOnlyCreditManager(1L); + + final GetDeliveryMethod getDeliveryMethod = + new GetDeliveryMethod(singleMessageCredit, queue); + final RecordDeliveryMethod getRecordMethod = new RecordDeliveryMethod() + { + + public void recordMessageDelivery(final ConsumerImpl sub, + final MessageInstance entry, + final long deliveryTag) + { + addUnacknowledgedMessage(entry, deliveryTag, null); + } + }; + + ConsumerTarget_0_8 target; + EnumSet<ConsumerImpl.Option> options = EnumSet.of(ConsumerImpl.Option.TRANSIENT, ConsumerImpl.Option.ACQUIRES, + ConsumerImpl.Option.SEES_REQUEUES); + if (acks) + { + + target = ConsumerTarget_0_8.createAckTarget(this, + AMQShortString.EMPTY_STRING, null, + singleMessageCredit, getDeliveryMethod, getRecordMethod); + } + else + { + target = ConsumerTarget_0_8.createGetNoAckTarget(this, + AMQShortString.EMPTY_STRING, null, + singleMessageCredit, getDeliveryMethod, getRecordMethod); + } + + ConsumerImpl sub = queue.addConsumer(target, null, AMQMessage.class, "", options); + sub.flush(); + sub.close(); + return getDeliveryMethod.hasDeliveredMessage(); + + + } + /** Sets this channel to be part of a local transaction */ public void setLocalTransactional() { @@ -250,7 +304,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> @Override public long getActivityTime() { - return _session.getLastReceivedTime(); + return _connection.getLastReceivedTime(); } }); _txnStarts.incrementAndGet(); @@ -324,27 +378,18 @@ public class AMQChannel<T extends AMQProtocolSession<T>> } public void publishContentHeader(ContentHeaderBody contentHeaderBody) - throws AMQException { - if (_currentMessage == null) + if (_logger.isDebugEnabled()) { - throw new AMQException("Received content header without previously receiving a BasicPublish frame"); + _logger.debug("Content header received on channel " + _channelId); } - else - { - if (_logger.isDebugEnabled()) - { - _logger.debug("Content header received on channel " + _channelId); - } - _currentMessage.setContentHeaderBody(contentHeaderBody); + _currentMessage.setContentHeaderBody(contentHeaderBody); - deliverCurrentMessageIfComplete(); - } + deliverCurrentMessageIfComplete(); } private void deliverCurrentMessageIfComplete() - throws AMQException { // check and deliver if header says body length is zero if (_currentMessage.allContentReceived()) @@ -355,7 +400,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> final MessageMetaData messageMetaData = new MessageMetaData(_currentMessage.getMessagePublishInfo(), _currentMessage.getContentHeader(), - getProtocolSession().getLastReceivedTime()); + getConnection().getLastReceivedTime()); final StoredMessage<MessageMetaData> handle = _messageStore.addMessage(messageMetaData); final AMQMessage amqMessage = createAMQMessage(_currentMessage, handle); @@ -430,7 +475,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> { long bodySize = _currentMessage.getSize(); long timestamp = _currentMessage.getContentHeader().getProperties().getTimestamp(); - _session.registerMessageReceived(bodySize, timestamp); + _connection.registerMessageReceived(bodySize, timestamp); _currentMessage = null; } } @@ -443,13 +488,13 @@ public class AMQChannel<T extends AMQProtocolSession<T>> * Pre-requisite: the current message is judged to have no destination queues. * * @throws AMQConnectionException if the message is mandatory close-on-no-route - * @see AMQProtocolSession#isCloseWhenNoRoute() + * @see AMQProtocolEngine#isCloseWhenNoRoute() */ - private void handleUnroutableMessage(AMQMessage message) throws AMQConnectionException + private void handleUnroutableMessage(AMQMessage message) { boolean mandatory = message.isMandatory(); String description = currentMessageDescription(); - boolean closeOnNoRoute = _session.isCloseWhenNoRoute(); + boolean closeOnNoRoute = _connection.isCloseWhenNoRoute(); if(_logger.isDebugEnabled()) { @@ -458,29 +503,29 @@ public class AMQChannel<T extends AMQProtocolSession<T>> description, mandatory, isTransactional(), closeOnNoRoute)); } - if (mandatory && isTransactional() && _session.isCloseWhenNoRoute()) + if (mandatory && isTransactional() && _connection.isCloseWhenNoRoute()) { - throw new AMQConnectionException( - AMQConstant.NO_ROUTE, - "No route for message " + currentMessageDescription(), - 0, 0, // default class and method ids - getProtocolSession().getProtocolVersion().getMajorVersion(), - getProtocolSession().getProtocolVersion().getMinorVersion(), - (Throwable) null); - } - - if (mandatory || message.isImmediate()) - { - _transaction.addPostTransactionAction(new WriteReturnAction(AMQConstant.NO_ROUTE, "No Route for message " + currentMessageDescription(), message)); + _connection.closeConnection(AMQConstant.NO_ROUTE, + "No route for message " + currentMessageDescription(), _channelId); } else { - AMQShortString exchangeName = _currentMessage.getExchangeName(); - AMQShortString routingKey = _currentMessage.getMessagePublishInfo().getRoutingKey(); + if (mandatory || message.isImmediate()) + { + _transaction.addPostTransactionAction(new WriteReturnAction(AMQConstant.NO_ROUTE, + "No Route for message " + + currentMessageDescription(), + message)); + } + else + { + AMQShortString exchangeName = _currentMessage.getExchangeName(); + AMQShortString routingKey = _currentMessage.getMessagePublishInfo().getRoutingKey(); - getVirtualHost().getEventLogger().message( - ExchangeMessages.DISCARDMSG(exchangeName == null ? null : exchangeName.asString(), - routingKey == null ? null : routingKey.asString())); + getVirtualHost().getEventLogger().message( + ExchangeMessages.DISCARDMSG(exchangeName == null ? null : exchangeName.asString(), + routingKey == null ? null : routingKey.asString())); + } } } @@ -499,13 +544,8 @@ public class AMQChannel<T extends AMQProtocolSession<T>> : _currentMessage.getMessagePublishInfo().getRoutingKey().toString()); } - public void publishContentBody(ContentBody contentBody) throws AMQException + public void publishContentBody(ContentBody contentBody) { - if (_currentMessage == null) - { - throw new AMQException("Received content body without previously receiving a Content Header"); - } - if (_logger.isDebugEnabled()) { _logger.debug(debugIdentity() + " content body received on channel " + _channelId); @@ -517,13 +557,6 @@ public class AMQChannel<T extends AMQProtocolSession<T>> deliverCurrentMessageIfComplete(); } - catch (AMQException e) - { - // we want to make sure we don't keep a reference to the message in the - // event of an error - _currentMessage = null; - throw e; - } catch (RuntimeException e) { // we want to make sure we don't keep a reference to the message in the @@ -566,9 +599,10 @@ public class AMQChannel<T extends AMQProtocolSession<T>> */ public AMQShortString consumeFromSource(AMQShortString tag, Collection<MessageSource> sources, boolean acks, FieldTable filters, boolean exclusive, boolean noLocal) - throws AMQException, MessageSource.ExistingConsumerPreventsExclusive, - MessageSource.ExistingExclusiveConsumer, AMQInvalidArgumentException, - MessageSource.ConsumerAccessRefused + throws MessageSource.ExistingConsumerPreventsExclusive, + MessageSource.ExistingExclusiveConsumer, + AMQInvalidArgumentException, + MessageSource.ConsumerAccessRefused, ConsumerTagInUseException { if (tag == null) { @@ -577,7 +611,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> if (_tag2SubscriptionTargetMap.containsKey(tag)) { - throw new AMQException("Consumer already exists with same tag: " + tag); + throw new ConsumerTagInUseException("Consumer already exists with same tag: " + tag); } ConsumerTarget_0_8 target; @@ -649,27 +683,11 @@ public class AMQChannel<T extends AMQProtocolSession<T>> } } } - catch (AccessControlException e) - { - _tag2SubscriptionTargetMap.remove(tag); - throw e; - } - catch (MessageSource.ExistingExclusiveConsumer e) - { - _tag2SubscriptionTargetMap.remove(tag); - throw e; - } - catch (MessageSource.ExistingConsumerPreventsExclusive e) - { - _tag2SubscriptionTargetMap.remove(tag); - throw e; - } - catch (AMQInvalidArgumentException e) - { - _tag2SubscriptionTargetMap.remove(tag); - throw e; - } - catch (MessageSource.ConsumerAccessRefused e) + catch (AccessControlException + | MessageSource.ExistingExclusiveConsumer + | MessageSource.ExistingConsumerPreventsExclusive + | AMQInvalidArgumentException + | MessageSource.ConsumerAccessRefused e) { _tag2SubscriptionTargetMap.remove(tag); throw e; @@ -730,7 +748,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> unsubscribeAllConsumers(); - for (Action<? super AMQChannel<T>> task : _taskList) + for (Action<? super AMQChannel> task : _taskList) { task.performAction(this); } @@ -897,9 +915,8 @@ public class AMQChannel<T extends AMQProtocolSession<T>> /** * Called to resend all outstanding unacknowledged messages to this same channel. * - * @throws AMQException When something goes wrong. */ - public void resend() throws AMQException + public void resend() { @@ -985,9 +1002,8 @@ public class AMQChannel<T extends AMQProtocolSession<T>> * @param multiple if true will acknowledge all messages up to an including the delivery tag. if false only * acknowledges the single message specified by the delivery tag * - * @throws AMQException if the delivery tag is unknown (e.g. not outstanding) on this channel */ - public void acknowledgeMessage(long deliveryTag, boolean multiple) throws AMQException + public void acknowledgeMessage(long deliveryTag, boolean multiple) { Collection<MessageInstance> ackedMessages = getAckedMessages(deliveryTag, multiple); _transaction.dequeue(ackedMessages, new MessageAcknowledgeAction(ackedMessages)); @@ -1084,22 +1100,13 @@ public class AMQChannel<T extends AMQProtocolSession<T>> public boolean isSuspended() { - return _suspended.get() || _closing.get() || _session.isClosing(); + return _suspended.get() || _closing.get() || _connection.isClosing(); } - public void commit() throws AMQException - { - commit(null, false); - } - - public void commit(final Runnable immediateAction, boolean async) throws AMQException + public void commit(final Runnable immediateAction, boolean async) { - if (!isTransactional()) - { - throw new AMQException("Fatal error: commit called on non-transactional channel"); - } if(async && _transaction instanceof LocalTransaction) { @@ -1132,17 +1139,8 @@ public class AMQChannel<T extends AMQProtocolSession<T>> } } - public void rollback() throws AMQException - { - rollback(NULL_TASK); - } - - public void rollback(Runnable postRollbackTask) throws AMQException + public void rollback(Runnable postRollbackTask) { - if (!isTransactional()) - { - throw new AMQException("Fatal error: commit called on non-transactional channel"); - } // stop all subscriptions _rollingBack = true; @@ -1200,7 +1198,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> public String toString() { - return "("+ _suspended.get() + ", " + _closing.get() + ", " + _session.isClosing() + ") "+"["+_session.toString()+":"+_channelId+"]"; + return "("+ _suspended.get() + ", " + _closing.get() + ", " + _connection.isClosing() + ") "+"["+ _connection.toString()+":"+_channelId+"]"; } public void setDefaultQueue(AMQQueue queue) @@ -1219,9 +1217,9 @@ public class AMQChannel<T extends AMQProtocolSession<T>> return _closing.get(); } - public AMQProtocolSession getProtocolSession() + public AMQProtocolEngine getConnection() { - return _session; + return _connection; } public FlowCreditManager getCreditManager() @@ -1261,13 +1259,9 @@ public class AMQChannel<T extends AMQProtocolSession<T>> private AMQMessage createAMQMessage(IncomingMessage incomingMessage, StoredMessage<MessageMetaData> handle) - throws AMQException { - AMQMessage message = new AMQMessage(handle, _session.getReference()); - - final BasicContentHeaderProperties properties = - incomingMessage.getContentHeader().getProperties(); + AMQMessage message = new AMQMessage(handle, _connection.getReference()); return message; } @@ -1275,7 +1269,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> private boolean checkMessageUserId(ContentHeaderBody header) { AMQShortString userID = header.getProperties().getUserId(); - return (!_messageAuthorizationRequired || _session.getAuthorizedPrincipal().getName().equals(userID == null? "" : userID.toString())); + return (!_messageAuthorizationRequired || _connection.getAuthorizedPrincipal().getName().equals(userID == null? "" : userID.toString())); } @@ -1286,14 +1280,14 @@ public class AMQChannel<T extends AMQProtocolSession<T>> } @Override - public T getConnectionModel() + public AMQProtocolEngine getConnectionModel() { - return _session; + return _connection; } public String getClientID() { - return String.valueOf(_session.getContextKey()); + return String.valueOf(_connection.getContextKey()); } public LogSubject getLogSubject() @@ -1308,13 +1302,13 @@ public class AMQChannel<T extends AMQProtocolSession<T>> } @Override - public void addDeleteTask(final Action<? super AMQChannel<T>> task) + public void addDeleteTask(final Action<? super AMQChannel> task) { _taskList.add(task); } @Override - public void removeDeleteTask(final Action<? super AMQChannel<T>> task) + public void removeDeleteTask(final Action<? super AMQChannel> task) { _taskList.remove(task); } @@ -1324,6 +1318,46 @@ public class AMQChannel<T extends AMQProtocolSession<T>> return _subject; } + public boolean hasCurrentMessage() + { + return _currentMessage != null; + } + + private class GetDeliveryMethod implements ClientDeliveryMethod + { + + private final FlowCreditManager _singleMessageCredit; + private final AMQQueue _queue; + private boolean _deliveredMessage; + + public GetDeliveryMethod(final FlowCreditManager singleMessageCredit, + final AMQQueue queue) + { + _singleMessageCredit = singleMessageCredit; + _queue = queue; + } + + @Override + public long deliverToClient(final ConsumerImpl sub, final ServerMessage message, + final InstanceProperties props, final long deliveryTag) + { + _singleMessageCredit.useCreditForMessage(message.getSize()); + long size = _connection.getProtocolOutputConverter().writeGetOk(message, + props, + AMQChannel.this.getChannelId(), + deliveryTag, + _queue.getQueueDepthMessages()); + + _deliveredMessage = true; + return size; + } + + public boolean hasDeliveredMessage() + { + return _deliveredMessage; + } + } + private class ImmediateAction implements Action<MessageInstance> { @@ -1352,7 +1386,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> public void postCommit() { final ProtocolOutputConverter outputConverter = - _session.getProtocolOutputConverter(); + _connection.getProtocolOutputConverter(); outputConverter.writeReturn(message.getMessagePublishInfo(), message.getContentHeaderBody(), @@ -1475,7 +1509,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> public void postCommit() { AMQMessage message = _reference.getMessage(); - _session.getProtocolOutputConverter().writeReturn(message.getMessagePublishInfo(), + _connection.getProtocolOutputConverter().writeReturn(message.getMessagePublishInfo(), message.getContentHeaderBody(), message, _channelId, @@ -1544,7 +1578,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> @Override public Object getConnectionReference() { - return getProtocolSession().getReference(); + return getConnection().getReference(); } public int getUnacknowledgedMessageCount() @@ -1554,9 +1588,9 @@ public class AMQChannel<T extends AMQProtocolSession<T>> private void flow(boolean flow) { - MethodRegistry methodRegistry = _session.getMethodRegistry(); + MethodRegistry methodRegistry = _connection.getMethodRegistry(); AMQMethodBody responseBody = methodRegistry.createChannelFlowBody(flow); - _session.writeFrame(responseBody.generateFrame(_channelId)); + _connection.writeFrame(responseBody.generateFrame(_channelId)); } @Override @@ -1567,7 +1601,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> public VirtualHostImpl getVirtualHost() { - return getProtocolSession().getVirtualHost(); + return getConnection().getVirtualHost(); } public void checkTransactionStatus(long openWarn, long openClose, long idleWarn, long idleClose) @@ -1581,11 +1615,11 @@ public class AMQChannel<T extends AMQProtocolSession<T>> */ private void closeConnection(String reason) throws AMQException { - Lock receivedLock = _session.getReceivedLock(); + Lock receivedLock = _connection.getReceivedLock(); receivedLock.lock(); try { - _session.close(AMQConstant.RESOURCE_ERROR, reason); + _connection.close(AMQConstant.RESOURCE_ERROR, reason); } finally { @@ -1593,7 +1627,7 @@ public class AMQChannel<T extends AMQProtocolSession<T>> } } - public void deadLetter(long deliveryTag) throws AMQException + public void deadLetter(long deliveryTag) { final UnacknowledgedMessageMap unackedMap = getUnacknowledgedMessageMap(); final MessageInstance rejectedQueueEntry = unackedMap.remove(deliveryTag); @@ -1816,4 +1850,1521 @@ public class AMQChannel<T extends AMQProtocolSession<T>> return 0L; } } + + @Override + public void receiveAccessRequest(final AMQShortString realm, + final boolean exclusive, + final boolean passive, + final boolean active, final boolean write, final boolean read) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] AccessRequest[" +" realm: " + realm + + " exclusive: " + exclusive + + " passive: " + passive + + " active: " + active + + " write: " + write + " read: " + read + " ]"); + } + + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + + if (ProtocolVersion.v0_91.equals(_connection.getProtocolVersion())) + { + _connection.closeConnection(AMQConstant.COMMAND_INVALID, + "AccessRequest not present in AMQP versions other than 0-8, 0-9", + _channelId); + } + else + { + // We don't implement access control class, but to keep clients happy that expect it + // always use the "0" ticket. + AccessRequestOkBody response = methodRegistry.createAccessRequestOkBody(0); + sync(); + _connection.writeFrame(response.generateFrame(_channelId)); + } + } + + @Override + public void receiveBasicAck(final long deliveryTag, final boolean multiple) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] BasicAck[" +" deliveryTag: " + deliveryTag + " multiple: " + multiple + " ]"); + } + + acknowledgeMessage(deliveryTag, multiple); + } + + @Override + public void receiveBasicCancel(final AMQShortString consumerTag, final boolean nowait) + { + + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] BasicCancel[" +" consumerTag: " + consumerTag + " noWait: " + nowait + " ]"); + } + + unsubscribeConsumer(consumerTag); + if (!nowait) + { + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + BasicCancelOkBody cancelOkBody = methodRegistry.createBasicCancelOkBody(consumerTag); + sync(); + _connection.writeFrame(cancelOkBody.generateFrame(_channelId)); + } + } + + @Override + public void receiveBasicConsume(final AMQShortString queue, + final AMQShortString consumerTag, + final boolean noLocal, + final boolean noAck, + final boolean exclusive, final boolean nowait, final FieldTable arguments) + { + + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] BasicConsume[" +" queue: " + queue + + " consumerTag: " + consumerTag + + " noLocal: " + noLocal + + " noAck: " + noAck + + " exclusive: " + exclusive + " nowait: " + nowait + " arguments: " + arguments + " ]"); + } + + AMQShortString consumerTag1 = consumerTag; + VirtualHostImpl<?, ?, ?> vHost = _connection.getVirtualHost(); + sync(); + String queueName = queue == null ? null : queue.asString(); + + MessageSource queue1 = queueName == null ? getDefaultQueue() : vHost.getQueue(queueName); + final Collection<MessageSource> sources = new HashSet<>(); + if (queue1 != null) + { + sources.add(queue1); + } + else if (vHost.getContextValue(Boolean.class, "qpid.enableMultiQueueConsumers") + && arguments != null + && arguments.get("x-multiqueue") instanceof Collection) + { + for (Object object : (Collection<Object>) arguments.get("x-multiqueue")) + { + String sourceName = String.valueOf(object); + sourceName = sourceName.trim(); + if (sourceName.length() != 0) + { + MessageSource source = vHost.getMessageSource(sourceName); + if (source == null) + { + sources.clear(); + break; + } + else + { + sources.add(source); + } + } + } + queueName = arguments.get("x-multiqueue").toString(); + } + + if (sources.isEmpty()) + { + if (_logger.isDebugEnabled()) + { + _logger.debug("No queue for '" + queueName + "'"); + } + if (queueName != null) + { + closeChannel(AMQConstant.NOT_FOUND, "No such queue, '" + queueName + "'"); + } + else + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, + "No queue name provided, no default queue defined.", _channelId); + } + } + else + { + try + { + consumerTag1 = consumeFromSource(consumerTag1, + sources, + !noAck, + arguments, + exclusive, + noLocal); + if (!nowait) + { + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + AMQMethodBody responseBody = methodRegistry.createBasicConsumeOkBody(consumerTag1); + _connection.writeFrame(responseBody.generateFrame(_channelId)); + + } + } + catch (ConsumerTagInUseException cte) + { + + _connection.closeConnection(AMQConstant.NOT_ALLOWED, + "Non-unique consumer tag, '" + consumerTag1 + + "'", _channelId); + } + catch (AMQInvalidArgumentException ise) + { + _connection.closeConnection(AMQConstant.ARGUMENT_INVALID, ise.getMessage(), _channelId); + + + } + catch (AMQQueue.ExistingExclusiveConsumer e) + { + _connection.closeConnection(AMQConstant.ACCESS_REFUSED, + "Cannot subscribe to queue " + + queue1.getName() + + " as it already has an existing exclusive consumer", _channelId); + + } + catch (AMQQueue.ExistingConsumerPreventsExclusive e) + { + _connection.closeConnection(AMQConstant.ACCESS_REFUSED, + "Cannot subscribe to queue " + + queue1.getName() + + " exclusively as it already has a consumer", _channelId); + + } + catch (AccessControlException e) + { + _connection.closeConnection(AMQConstant.ACCESS_REFUSED, "Cannot subscribe to queue " + + queue1.getName() + + " permission denied", _channelId); + + } + catch (MessageSource.ConsumerAccessRefused consumerAccessRefused) + { + _connection.closeConnection(AMQConstant.ACCESS_REFUSED, + "Cannot subscribe to queue " + + queue1.getName() + + " as it already has an incompatible exclusivity policy", _channelId); + + } + + } + } + + @Override + public void receiveBasicGet(final AMQShortString queueName, final boolean noAck) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] BasicGet[" +" queue: " + queueName + " noAck: " + noAck + " ]"); + } + + VirtualHostImpl vHost = _connection.getVirtualHost(); + sync(); + AMQQueue queue = queueName == null ? getDefaultQueue() : vHost.getQueue(queueName.toString()); + if (queue == null) + { + _logger.info("No queue for '" + queueName + "'"); + if (queueName != null) + { + _connection.closeConnection(AMQConstant.NOT_FOUND, "No such queue, '" + queueName + "'", _channelId); + + } + else + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, + "No queue name provided, no default queue defined.", _channelId); + + } + } + else + { + + try + { + if (!performGet(queue, !noAck)) + { + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + + BasicGetEmptyBody responseBody = methodRegistry.createBasicGetEmptyBody(null); + + _connection.writeFrame(responseBody.generateFrame(_channelId)); + } + } + catch (AccessControlException e) + { + _connection.closeConnection(AMQConstant.ACCESS_REFUSED, e.getMessage(), _channelId); + } + catch (MessageSource.ExistingExclusiveConsumer e) + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, "Queue has an exclusive consumer", _channelId); + } + catch (MessageSource.ExistingConsumerPreventsExclusive e) + { + _connection.closeConnection(AMQConstant.INTERNAL_ERROR, + "The GET request has been evaluated as an exclusive consumer, " + + "this is likely due to a programming error in the Qpid broker", _channelId); + } + catch (MessageSource.ConsumerAccessRefused consumerAccessRefused) + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, + "Queue has an incompatible exclusivity policy", _channelId); + } + } + } + + @Override + public void receiveBasicPublish(final AMQShortString exchangeName, + final AMQShortString routingKey, + final boolean mandatory, + final boolean immediate) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] BasicPublish[" +" exchange: " + exchangeName + + " routingKey: " + routingKey + + " mandatory: " + mandatory + + " immediate: " + immediate + " ]"); + } + + VirtualHostImpl vHost = _connection.getVirtualHost(); + + MessageDestination destination; + + if (isDefaultExchange(exchangeName)) + { + destination = vHost.getDefaultDestination(); + } + else + { + destination = vHost.getMessageDestination(exchangeName.toString()); + } + + // if the exchange does not exist we raise a channel exception + if (destination == null) + { + closeChannel(AMQConstant.NOT_FOUND, "Unknown exchange name: " + exchangeName); + } + else + { + + MessagePublishInfo info = new MessagePublishInfo(exchangeName, + immediate, + mandatory, + routingKey); + + try + { + setPublishFrame(info, destination); + } + catch (AccessControlException e) + { + _connection.closeConnection(AMQConstant.ACCESS_REFUSED, e.getMessage(), getChannelId()); + + } + } + } + + @Override + public void receiveBasicQos(final long prefetchSize, final int prefetchCount, final boolean global) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] BasicQos[" +" prefetchSize: " + prefetchSize + " prefetchCount: " + prefetchCount + " global: " + global + " ]"); + } + + sync(); + setCredit(prefetchSize, prefetchCount); + + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + AMQMethodBody responseBody = methodRegistry.createBasicQosOkBody(); + _connection.writeFrame(responseBody.generateFrame(getChannelId())); + + } + + @Override + public void receiveBasicRecover(final boolean requeue, final boolean sync) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] BasicRecover[" + " requeue: " + requeue + " sync: " + sync + " ]"); + } + + resend(); + + if (sync) + { + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + AMQMethodBody recoverOk = methodRegistry.createBasicRecoverSyncOkBody(); + sync(); + _connection.writeFrame(recoverOk.generateFrame(getChannelId())); + + } + + } + + @Override + public void receiveBasicReject(final long deliveryTag, final boolean requeue) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] BasicReject[" +" deliveryTag: " + deliveryTag + " requeue: " + requeue + " ]"); + } + + MessageInstance message = getUnacknowledgedMessageMap().get(deliveryTag); + + if (message == null) + { + _logger.warn("Dropping reject request as message is null for tag:" + deliveryTag); + } + else + { + + if (message.getMessage() == null) + { + _logger.warn("Message has already been purged, unable to Reject."); + } + else + { + + if (_logger.isDebugEnabled()) + { + _logger.debug("Rejecting: DT:" + deliveryTag + + "-" + message.getMessage() + + ": Requeue:" + requeue + + + " on channel:" + debugIdentity()); + } + + if (requeue) + { + //this requeue represents a message rejected from the pre-dispatch queue + //therefore we need to amend the delivery counter. + message.decrementDeliveryCount(); + + requeue(deliveryTag); + } + else + { + // Since the Java client abuses the reject flag for requeing after rollback, we won't set reject here + // as it would prevent redelivery + // message.reject(); + + final boolean maxDeliveryCountEnabled = isMaxDeliveryCountEnabled(deliveryTag); + _logger.debug("maxDeliveryCountEnabled: " + + maxDeliveryCountEnabled + + " deliveryTag " + + deliveryTag); + if (maxDeliveryCountEnabled) + { + final boolean deliveredTooManyTimes = isDeliveredTooManyTimes(deliveryTag); + _logger.debug("deliveredTooManyTimes: " + + deliveredTooManyTimes + + " deliveryTag " + + deliveryTag); + if (deliveredTooManyTimes) + { + deadLetter(deliveryTag); + } + else + { + //this requeue represents a message rejected because of a recover/rollback that we + //are not ready to DLQ. We rely on the reject command to resend from the unacked map + //and therefore need to increment the delivery counter so we cancel out the effect + //of the AMQChannel#resend() decrement. + message.incrementDeliveryCount(); + } + } + else + { + requeue(deliveryTag); + } + } + } + } + } + + @Override + public void receiveChannelClose(final int replyCode, + final AMQShortString replyText, + final int classId, + final int methodId) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] ChannelClose[" +" replyCode: " + replyCode + " replyText: " + replyText + " classId: " + classId + " methodId: " + methodId + " ]"); + } + + + sync(); + _connection.closeChannel(this); + + _connection.writeFrame(new AMQFrame(getChannelId(), + _connection.getMethodRegistry().createChannelCloseOkBody())); + } + + @Override + public void receiveChannelCloseOk() + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] ChannelCloseOk"); + } + + _connection.closeChannelOk(getChannelId()); + } + + @Override + public void receiveMessageContent(final byte[] data) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] MessageContent[" +" data: " + hex(data,_connection.getBinaryDataLimit()) + " ] "); + } + + if(hasCurrentMessage()) + { + publishContentBody(new ContentBody(data)); + } + else + { + _connection.closeConnection(AMQConstant.COMMAND_INVALID, + "Attempt to send a content header without first sending a publish frame", + _channelId); + } + } + + @Override + public void receiveMessageHeader(final BasicContentHeaderProperties properties, final long bodySize) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] MessageHeader[ properties: {" + properties + "} bodySize: " + bodySize + " ]"); + } + + if(hasCurrentMessage()) + { + publishContentHeader(new ContentHeaderBody(properties, bodySize)); + } + else + { + _connection.closeConnection(AMQConstant.COMMAND_INVALID, + "Attempt to send a content header without first sending a publish frame", + _channelId); + } + } + + @Override + public boolean ignoreAllButCloseOk() + { + return _connection.ignoreAllButCloseOk() || _connection.channelAwaitingClosure(_channelId); + } + + @Override + public void receiveChannelFlow(final boolean active) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] ChannelFlow[" +" active: " + active + " ]"); + } + + + sync(); + setSuspended(!active); + + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + AMQMethodBody responseBody = methodRegistry.createChannelFlowOkBody(active); + _connection.writeFrame(responseBody.generateFrame(getChannelId())); + + } + + @Override + public void receiveChannelFlowOk(final boolean active) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] ChannelFlowOk[" +" active: " + active + " ]"); + } + + // TODO - should we do anything here? + } + + @Override + public void receiveExchangeBound(final AMQShortString exchangeName, + final AMQShortString routingKey, + final AMQShortString queueName) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] ExchangeBound[" +" exchange: " + exchangeName + " routingKey: " + + routingKey + " queue: " + queueName + " ]"); + } + + VirtualHostImpl virtualHost = _connection.getVirtualHost(); + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + + sync(); + + int replyCode; + String replyText; + + if (isDefaultExchange(exchangeName)) + { + if (routingKey == null) + { + if (queueName == null) + { + replyCode = virtualHost.getQueues().isEmpty() + ? ExchangeBoundOkBody.NO_BINDINGS + : ExchangeBoundOkBody.OK; + replyText = null; + + } + else + { + AMQQueue queue = virtualHost.getQueue(queueName.toString()); + if (queue == null) + { + replyCode = ExchangeBoundOkBody.QUEUE_NOT_FOUND; + replyText = "Queue '" + queueName + "' not found"; + } + else + { + replyCode = ExchangeBoundOkBody.OK; + replyText = null; + } + } + } + else + { + if (queueName == null) + { + replyCode = virtualHost.getQueue(routingKey.toString()) == null + ? ExchangeBoundOkBody.NO_QUEUE_BOUND_WITH_RK + : ExchangeBoundOkBody.OK; + replyText = null; + } + else + { + AMQQueue queue = virtualHost.getQueue(queueName.toString()); + if (queue == null) + { + + replyCode = ExchangeBoundOkBody.QUEUE_NOT_FOUND; + replyText = "Queue '" + queueName + "' not found"; + } + else + { + replyCode = queueName.equals(routingKey) + ? ExchangeBoundOkBody.OK + : ExchangeBoundOkBody.SPECIFIC_QUEUE_NOT_BOUND_WITH_RK; + replyText = null; + } + } + } + } + else + { + ExchangeImpl exchange = virtualHost.getExchange(exchangeName.toString()); + if (exchange == null) + { + + replyCode = ExchangeBoundOkBody.EXCHANGE_NOT_FOUND; + replyText = "Exchange '" + exchangeName + "' not found"; + } + else if (routingKey == null) + { + if (queueName == null) + { + if (exchange.hasBindings()) + { + replyCode = ExchangeBoundOkBody.OK; + replyText = null; + } + else + { + replyCode = ExchangeBoundOkBody.NO_BINDINGS; + replyText = null; + } + } + else + { + + AMQQueue queue = virtualHost.getQueue(queueName.toString()); + if (queue == null) + { + replyCode = ExchangeBoundOkBody.QUEUE_NOT_FOUND; + replyText = "Queue '" + queueName + "' not found"; + } + else + { + if (exchange.isBound(queue)) + { + replyCode = ExchangeBoundOkBody.OK; + replyText = null; + } + else + { + replyCode = ExchangeBoundOkBody.QUEUE_NOT_BOUND; + replyText = "Queue '" + + queueName + + "' not bound to exchange '" + + exchangeName + + "'"; + } + } + } + } + else if (queueName != null) + { + AMQQueue queue = virtualHost.getQueue(queueName.toString()); + if (queue == null) + { + replyCode = ExchangeBoundOkBody.QUEUE_NOT_FOUND; + replyText = "Queue '" + queueName + "' not found"; + } + else + { + String bindingKey = routingKey == null ? null : routingKey.asString(); + if (exchange.isBound(bindingKey, queue)) + { + + replyCode = ExchangeBoundOkBody.OK; + replyText = null; + } + else + { + replyCode = ExchangeBoundOkBody.SPECIFIC_QUEUE_NOT_BOUND_WITH_RK; + replyText = "Queue '" + queueName + "' not bound with routing key '" + + routingKey + "' to exchange '" + exchangeName + "'"; + + } + } + } + else + { + if (exchange.isBound(routingKey == null ? "" : routingKey.asString())) + { + + replyCode = ExchangeBoundOkBody.OK; + replyText = null; + } + else + { + replyCode = ExchangeBoundOkBody.NO_QUEUE_BOUND_WITH_RK; + replyText = + "No queue bound with routing key '" + routingKey + "' to exchange '" + exchangeName + "'"; + } + } + } + + ExchangeBoundOkBody exchangeBoundOkBody = + methodRegistry.createExchangeBoundOkBody(replyCode, AMQShortString.validValueOf(replyText)); + + _connection.writeFrame(exchangeBoundOkBody.generateFrame(getChannelId())); + + } + + @Override + public void receiveExchangeDeclare(final AMQShortString exchangeName, + final AMQShortString type, + final boolean passive, + final boolean durable, + final boolean autoDelete, + final boolean internal, + final boolean nowait, + final FieldTable arguments) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] ExchangeDeclare[" +" exchange: " + exchangeName + + " type: " + type + + " passive: " + passive + + " durable: " + durable + + " autoDelete: " + autoDelete + + " internal: " + internal + " nowait: " + nowait + " arguments: " + arguments + " ]"); + } + + ExchangeImpl exchange; + VirtualHostImpl<?, ?, ?> virtualHost = _connection.getVirtualHost(); + if (isDefaultExchange(exchangeName)) + { + if (!new AMQShortString(ExchangeDefaults.DIRECT_EXCHANGE_CLASS).equals(type)) + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, "Attempt to redeclare default exchange: " + + " of type " + + ExchangeDefaults.DIRECT_EXCHANGE_CLASS + + " to " + type + ".", getChannelId()); + } + else if (!nowait) + { + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + AMQMethodBody responseBody = methodRegistry.createExchangeDeclareOkBody(); + sync(); + _connection.writeFrame(responseBody.generateFrame(getChannelId())); + } + + } + else + { + if (passive) + { + exchange = virtualHost.getExchange(exchangeName.toString()); + if (exchange == null) + { + closeChannel(AMQConstant.NOT_FOUND, "Unknown exchange: " + exchangeName); + } + else if (!(type == null || type.length() == 0) && !exchange.getType().equals(type.asString())) + { + + _connection.closeConnection(AMQConstant.NOT_ALLOWED, "Attempt to redeclare exchange: " + + + exchangeName + + " of type " + + exchange.getType() + + " to " + + type + + ".", getChannelId()); + } + else if (!nowait) + { + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + AMQMethodBody responseBody = methodRegistry.createExchangeDeclareOkBody(); + sync(); + _connection.writeFrame(responseBody.generateFrame(getChannelId())); + } + + } + else + { + try + { + String name = exchangeName == null ? null : exchangeName.intern().toString(); + String typeString = type == null ? null : type.intern().toString(); + + Map<String, Object> attributes = new HashMap<String, Object>(); + if (arguments != null) + { + attributes.putAll(FieldTable.convertToMap(arguments)); + } + attributes.put(Exchange.ID, null); + attributes.put(Exchange.NAME, name); + attributes.put(Exchange.TYPE, typeString); + attributes.put(Exchange.DURABLE, durable); + attributes.put(Exchange.LIFETIME_POLICY, + autoDelete ? LifetimePolicy.DELETE_ON_NO_LINKS : LifetimePolicy.PERMANENT); + if (!attributes.containsKey(Exchange.ALTERNATE_EXCHANGE)) + { + attributes.put(Exchange.ALTERNATE_EXCHANGE, null); + } + exchange = virtualHost.createExchange(attributes); + + if (!nowait) + { + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + AMQMethodBody responseBody = methodRegistry.createExchangeDeclareOkBody(); + sync(); + _connection.writeFrame(responseBody.generateFrame( + getChannelId())); + } + + } + catch (ReservedExchangeNameException e) + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, + "Attempt to declare exchange: " + exchangeName + + " which begins with reserved prefix.", getChannelId()); + + + } + catch (ExchangeExistsException e) + { + exchange = e.getExistingExchange(); + if (!new AMQShortString(exchange.getType()).equals(type)) + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, "Attempt to redeclare exchange: " + + exchangeName + " of type " + + exchange.getType() + + " to " + type + ".", getChannelId()); + + } + } + catch (NoFactoryForTypeException e) + { + _connection.closeConnection(AMQConstant.COMMAND_INVALID, "Unknown exchange type '" + + e.getType() + + "' for exchange '" + + exchangeName + + "'", getChannelId()); + + } + catch (AccessControlException e) + { + _connection.closeConnection(AMQConstant.ACCESS_REFUSED, e.getMessage(), getChannelId()); + + } + catch (UnknownConfiguredObjectException e) + { + // note - since 0-8/9/9-1 can't set the alt. exchange this exception should never occur + final String message = "Unknown alternate exchange " + + (e.getName() != null + ? "name: \"" + e.getName() + "\"" + : "id: " + e.getId()); + _connection.closeConnection(AMQConstant.NOT_FOUND, message, getChannelId()); + + } + catch (IllegalArgumentException e) + { + _connection.closeConnection(AMQConstant.COMMAND_INVALID, "Error creating exchange '" + + exchangeName + + "': " + + e.getMessage(), getChannelId()); + + } + } + } + + } + + @Override + public void receiveExchangeDelete(final AMQShortString exchangeStr, final boolean ifUnused, final boolean nowait) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] ExchangeDelete[" +" exchange: " + exchangeStr + " ifUnused: " + ifUnused + " nowait: " + nowait + " ]"); + } + + + VirtualHostImpl virtualHost = _connection.getVirtualHost(); + sync(); + try + { + + if (isDefaultExchange(exchangeStr)) + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, + "Default Exchange cannot be deleted", getChannelId()); + + } + + else + { + final String exchangeName = exchangeStr.toString(); + + final ExchangeImpl exchange = virtualHost.getExchange(exchangeName); + if (exchange == null) + { + closeChannel(AMQConstant.NOT_FOUND, "No such exchange: " + exchangeStr); + } + else + { + virtualHost.removeExchange(exchange, !ifUnused); + + ExchangeDeleteOkBody responseBody = _connection.getMethodRegistry().createExchangeDeleteOkBody(); + + _connection.writeFrame(responseBody.generateFrame(getChannelId())); + } + } + } + catch (ExchangeIsAlternateException e) + { + closeChannel(AMQConstant.NOT_ALLOWED, "Exchange in use as an alternate exchange"); + } + catch (RequiredExchangeException e) + { + closeChannel(AMQConstant.NOT_ALLOWED, + "Exchange '" + exchangeStr + "' cannot be deleted"); + } + catch (AccessControlException e) + { + _connection.closeConnection(AMQConstant.ACCESS_REFUSED, e.getMessage(), getChannelId()); + } + } + + @Override + public void receiveQueueBind(final AMQShortString queueName, + final AMQShortString exchange, + AMQShortString routingKey, + final boolean nowait, + final FieldTable argumentsTable) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] QueueBind[" +" queue: " + queueName + + " exchange: " + exchange + + " bindingKey: " + routingKey + + " nowait: " + nowait + " arguments: " + argumentsTable + " ]"); + } + + VirtualHostImpl virtualHost = _connection.getVirtualHost(); + AMQQueue<?> queue; + if (queueName == null) + { + + queue = getDefaultQueue(); + + if (queue != null) + { + if (routingKey == null) + { + routingKey = AMQShortString.valueOf(queue.getName()); + } + else + { + routingKey = routingKey.intern(); + } + } + } + else + { + queue = virtualHost.getQueue(queueName.toString()); + routingKey = routingKey == null ? AMQShortString.EMPTY_STRING : routingKey.intern(); + } + + if (queue == null) + { + String message = queueName == null + ? "No default queue defined on channel and queue was null" + : "Queue " + queueName + " does not exist."; + closeChannel(AMQConstant.NOT_FOUND, message); + } + else if (isDefaultExchange(exchange)) + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, + "Cannot bind the queue " + queueName + " to the default exchange", getChannelId()); + + } + else + { + + final String exchangeName = exchange.toString(); + + final ExchangeImpl exch = virtualHost.getExchange(exchangeName); + if (exch == null) + { + closeChannel(AMQConstant.NOT_FOUND, + "Exchange " + exchangeName + " does not exist."); + } + else + { + + try + { + + Map<String, Object> arguments = FieldTable.convertToMap(argumentsTable); + String bindingKey = String.valueOf(routingKey); + + if (!exch.isBound(bindingKey, arguments, queue)) + { + + if (!exch.addBinding(bindingKey, queue, arguments) + && ExchangeDefaults.TOPIC_EXCHANGE_CLASS.equals( + exch.getType())) + { + exch.replaceBinding(bindingKey, queue, arguments); + } + } + + if (_logger.isInfoEnabled()) + { + _logger.info("Binding queue " + + queue + + " to exchange " + + exch + + " with routing key " + + routingKey); + } + if (!nowait) + { + sync(); + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + AMQMethodBody responseBody = methodRegistry.createQueueBindOkBody(); + _connection.writeFrame(responseBody.generateFrame(getChannelId())); + + } + } + catch (AccessControlException e) + { + _connection.closeConnection(AMQConstant.ACCESS_REFUSED, e.getMessage(), getChannelId()); + } + } + } + } + + @Override + public void receiveQueueDeclare(final AMQShortString queueStr, + final boolean passive, + final boolean durable, + final boolean exclusive, + final boolean autoDelete, + final boolean nowait, + final FieldTable arguments) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] QueueDeclare[" +" queue: " + queueStr + + " passive: " + passive + + " durable: " + durable + + " exclusive: " + exclusive + + " autoDelete: " + autoDelete + " nowait: " + nowait + " arguments: " + arguments + " ]"); + } + + VirtualHostImpl virtualHost = _connection.getVirtualHost(); + + final AMQShortString queueName; + + // if we aren't given a queue name, we create one which we return to the client + if ((queueStr == null) || (queueStr.length() == 0)) + { + queueName = new AMQShortString("tmp_" + UUID.randomUUID()); + } + else + { + queueName = queueStr.intern(); + } + + AMQQueue queue; + + //TODO: do we need to check that the queue already exists with exactly the same "configuration"? + + + if (passive) + { + queue = virtualHost.getQueue(queueName.toString()); + if (queue == null) + { + closeChannel(AMQConstant.NOT_FOUND, + "Queue: " + + queueName + + " not found on VirtualHost(" + + virtualHost + + ")."); + } + else + { + if (!queue.verifySessionAccess(this)) + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, "Queue " + + queue.getName() + + " is exclusive, but not created on this Connection.", getChannelId()); + } + else + { + //set this as the default queue on the channel: + setDefaultQueue(queue); + if (!nowait) + { + sync(); + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + QueueDeclareOkBody responseBody = + methodRegistry.createQueueDeclareOkBody(queueName, + queue.getQueueDepthMessages(), + queue.getConsumerCount()); + _connection.writeFrame(responseBody.generateFrame(getChannelId())); + + _logger.info("Queue " + queueName + " declared successfully"); + } + } + } + } + else + { + + try + { + Map<String, Object> attributes = + QueueArgumentsConverter.convertWireArgsToModel(FieldTable.convertToMap(arguments)); + final String queueNameString = AMQShortString.toString(queueName); + attributes.put(Queue.NAME, queueNameString); + attributes.put(Queue.ID, UUID.randomUUID()); + attributes.put(Queue.DURABLE, durable); + + LifetimePolicy lifetimePolicy; + ExclusivityPolicy exclusivityPolicy; + + if (exclusive) + { + lifetimePolicy = autoDelete + ? LifetimePolicy.DELETE_ON_NO_OUTBOUND_LINKS + : durable ? LifetimePolicy.PERMANENT : LifetimePolicy.DELETE_ON_CONNECTION_CLOSE; + exclusivityPolicy = durable ? ExclusivityPolicy.CONTAINER : ExclusivityPolicy.CONNECTION; + } + else + { + lifetimePolicy = autoDelete ? LifetimePolicy.DELETE_ON_NO_OUTBOUND_LINKS : LifetimePolicy.PERMANENT; + exclusivityPolicy = ExclusivityPolicy.NONE; + } + + attributes.put(Queue.EXCLUSIVE, exclusivityPolicy); + attributes.put(Queue.LIFETIME_POLICY, lifetimePolicy); + + + queue = virtualHost.createQueue(attributes); + + setDefaultQueue(queue); + + if (!nowait) + { + sync(); + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + QueueDeclareOkBody responseBody = + methodRegistry.createQueueDeclareOkBody(queueName, + queue.getQueueDepthMessages(), + queue.getConsumerCount()); + _connection.writeFrame(responseBody.generateFrame(getChannelId())); + + _logger.info("Queue " + queueName + " declared successfully"); + } + } + catch (QueueExistsException qe) + { + + queue = qe.getExistingQueue(); + + if (!queue.verifySessionAccess(this)) + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, "Queue " + + queue.getName() + + " is exclusive, but not created on this Connection.", getChannelId()); + + } + else if (queue.isExclusive() != exclusive) + { + + closeChannel(AMQConstant.ALREADY_EXISTS, + "Cannot re-declare queue '" + + queue.getName() + + "' with different exclusivity (was: " + + queue.isExclusive() + + " requested " + + exclusive + + ")"); + } + else if ((autoDelete + && queue.getLifetimePolicy() != LifetimePolicy.DELETE_ON_NO_OUTBOUND_LINKS) + || (!autoDelete && queue.getLifetimePolicy() != ((exclusive + && !durable) + ? LifetimePolicy.DELETE_ON_CONNECTION_CLOSE + : LifetimePolicy.PERMANENT))) + { + closeChannel(AMQConstant.ALREADY_EXISTS, + "Cannot re-declare queue '" + + queue.getName() + + "' with different lifetime policy (was: " + + queue.getLifetimePolicy() + + " requested autodelete: " + + autoDelete + + ")"); + } + else if (queue.isDurable() != durable) + { + closeChannel(AMQConstant.ALREADY_EXISTS, + "Cannot re-declare queue '" + + queue.getName() + + "' with different durability (was: " + + queue.isDurable() + + " requested " + + durable + + ")"); + } + else + { + setDefaultQueue(queue); + if (!nowait) + { + sync(); + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + QueueDeclareOkBody responseBody = + methodRegistry.createQueueDeclareOkBody(queueName, + queue.getQueueDepthMessages(), + queue.getConsumerCount()); + _connection.writeFrame(responseBody.generateFrame(getChannelId())); + + _logger.info("Queue " + queueName + " declared successfully"); + } + } + } + catch (AccessControlException e) + { + _connection.closeConnection(AMQConstant.ACCESS_REFUSED, e.getMessage(), getChannelId()); + } + + } + } + + @Override + public void receiveQueueDelete(final AMQShortString queueName, + final boolean ifUnused, + final boolean ifEmpty, + final boolean nowait) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] QueueDelete[" +" queue: " + queueName + " ifUnused: " + ifUnused + " ifEmpty: " + ifEmpty + " nowait: " + nowait + " ]"); + } + + VirtualHostImpl virtualHost = _connection.getVirtualHost(); + sync(); + AMQQueue queue; + if (queueName == null) + { + + //get the default queue on the channel: + queue = getDefaultQueue(); + } + else + { + queue = virtualHost.getQueue(queueName.toString()); + } + + if (queue == null) + { + closeChannel(AMQConstant.NOT_FOUND, "Queue " + queueName + " does not exist."); + + } + else + { + if (ifEmpty && !queue.isEmpty()) + { + closeChannel(AMQConstant.IN_USE, "Queue: " + queueName + " is not empty."); + } + else if (ifUnused && !queue.isUnused()) + { + // TODO - Error code + closeChannel(AMQConstant.IN_USE, "Queue: " + queueName + " is still used."); + } + else + { + if (!queue.verifySessionAccess(this)) + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, "Queue " + + queue.getName() + + " is exclusive, but not created on this Connection.", getChannelId()); + + } + else + { + try + { + int purged = virtualHost.removeQueue(queue); + + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + QueueDeleteOkBody responseBody = methodRegistry.createQueueDeleteOkBody(purged); + _connection.writeFrame(responseBody.generateFrame(getChannelId())); + } + catch (AccessControlException e) + { + _connection.closeConnection(AMQConstant.ACCESS_REFUSED, e.getMessage(), getChannelId()); + + } + } + } + } + } + + @Override + public void receiveQueuePurge(final AMQShortString queueName, final boolean nowait) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] QueuePurge[" +" queue: " + queueName + " nowait: " + nowait + " ]"); + } + + VirtualHostImpl virtualHost = _connection.getVirtualHost(); + AMQQueue queue = null; + if (queueName == null && (queue = getDefaultQueue()) == null) + { + + _connection.closeConnection(AMQConstant.NOT_ALLOWED, "No queue specified.", getChannelId()); + } + else if ((queueName != null) && (queue = virtualHost.getQueue(queueName.toString())) == null) + { + closeChannel(AMQConstant.NOT_FOUND, "Queue " + queueName + " does not exist."); + } + else if (!queue.verifySessionAccess(this)) + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, + "Queue is exclusive, but not created on this Connection.", getChannelId()); + } + else + { + try + { + long purged = queue.clearQueue(); + if (!nowait) + { + sync(); + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + AMQMethodBody responseBody = methodRegistry.createQueuePurgeOkBody(purged); + _connection.writeFrame(responseBody.generateFrame(getChannelId())); + + } + } + catch (AccessControlException e) + { + _connection.closeConnection(AMQConstant.ACCESS_REFUSED, e.getMessage(), getChannelId()); + + } + + } + } + + @Override + public void receiveQueueUnbind(final AMQShortString queueName, + final AMQShortString exchange, + final AMQShortString routingKey, + final FieldTable arguments) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] QueueUnbind[" +" queue: " + queueName + + " exchange: " + exchange + + " bindingKey: " + routingKey + + " arguments: " + arguments + " ]"); + } + + VirtualHostImpl virtualHost = _connection.getVirtualHost(); + + + final boolean useDefaultQueue = queueName == null; + final AMQQueue queue = useDefaultQueue + ? getDefaultQueue() + : virtualHost.getQueue(queueName.toString()); + + + if (queue == null) + { + String message = useDefaultQueue + ? "No default queue defined on channel and queue was null" + : "Queue " + queueName + " does not exist."; + closeChannel(AMQConstant.NOT_FOUND, message); + } + else if (isDefaultExchange(exchange)) + { + _connection.closeConnection(AMQConstant.NOT_ALLOWED, "Cannot unbind the queue " + + queue.getName() + + " from the default exchange", getChannelId()); + + } + else + { + + final ExchangeImpl exch = virtualHost.getExchange(exchange.toString()); + + if (exch == null) + { + closeChannel(AMQConstant.NOT_FOUND, "Exchange " + exchange + " does not exist."); + } + else if (!exch.hasBinding(String.valueOf(routingKey), queue)) + { + closeChannel(AMQConstant.NOT_FOUND, "No such binding"); + } + else + { + try + { + exch.deleteBinding(String.valueOf(routingKey), queue); + + final AMQMethodBody responseBody = _connection.getMethodRegistry().createQueueUnbindOkBody(); + sync(); + _connection.writeFrame(responseBody.generateFrame(getChannelId())); + } + catch (AccessControlException e) + { + _connection.closeConnection(AMQConstant.ACCESS_REFUSED, e.getMessage(), getChannelId()); + + } + } + + } + } + + @Override + public void receiveTxSelect() + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] TxSelect"); + } + + setLocalTransactional(); + + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + TxSelectOkBody responseBody = methodRegistry.createTxSelectOkBody(); + _connection.writeFrame(responseBody.generateFrame(_channelId)); + + } + + @Override + public void receiveTxCommit() + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] TxCommit"); + } + + + if (!isTransactional()) + { + closeChannel(AMQConstant.COMMAND_INVALID, + "Fatal error: commit called on non-transactional channel"); + } + commit(new Runnable() + { + + @Override + public void run() + { + MethodRegistry methodRegistry = _connection.getMethodRegistry(); + AMQMethodBody responseBody = methodRegistry.createTxCommitOkBody(); + _connection.writeFrame(responseBody.generateFrame(_channelId)); + } + }, true); + + } + + @Override + public void receiveTxRollback() + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + _channelId + "] TxRollback"); + } + + if (!isTransactional()) + { + closeChannel(AMQConstant.COMMAND_INVALID, + "Fatal error: rollback called on non-transactional channel"); + } + + final MethodRegistry methodRegistry = _connection.getMethodRegistry(); + final AMQMethodBody responseBody = methodRegistry.createTxRollbackOkBody(); + + Runnable task = new Runnable() + { + + public void run() + { + _connection.writeFrame(responseBody.generateFrame(_channelId)); + } + }; + + rollback(task); + + //Now resend all the unacknowledged messages back to the original subscribers. + //(Must be done after the TxnRollback-ok response). + // Why, are we not allowed to send messages back to client before the ok method? + resend(); + } + + + private void closeChannel(final AMQConstant cause, final String message) + { + _connection.closeChannelAndWriteFrame(this, cause, message); + } + + + private boolean isDefaultExchange(final AMQShortString exchangeName) + { + return exchangeName == null || AMQShortString.EMPTY_STRING.equals(exchangeName); + } + } diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQMessage.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQMessage.java index 869de2f3a5..716a84eeb0 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQMessage.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQMessage.java @@ -24,7 +24,7 @@ import org.apache.log4j.Logger; import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.ContentHeaderBody; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.message.AMQMessageHeader; import org.apache.qpid.server.message.AbstractServerMessageImpl; import org.apache.qpid.server.store.StoredMessage; diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolEngine.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolEngine.java index a59f173d2f..413cf49eaf 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolEngine.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolEngine.java @@ -21,9 +21,13 @@ package org.apache.qpid.server.protocol.v0_8; import java.io.IOException; +import java.lang.reflect.InvocationHandler; +import java.lang.reflect.Method; +import java.lang.reflect.Proxy; import java.net.InetSocketAddress; import java.net.SocketAddress; import java.nio.ByteBuffer; +import java.security.AccessControlException; import java.security.AccessController; import java.security.Principal; import java.security.PrivilegedAction; @@ -41,11 +45,11 @@ import java.util.concurrent.locks.Lock; import java.util.concurrent.locks.ReentrantLock; import javax.security.auth.Subject; +import javax.security.sasl.SaslException; import javax.security.sasl.SaslServer; import org.apache.log4j.Logger; -import org.apache.qpid.AMQChannelException; import org.apache.qpid.AMQConnectionException; import org.apache.qpid.AMQException; import org.apache.qpid.codec.AMQDecoder; @@ -54,7 +58,6 @@ import org.apache.qpid.common.ServerPropertyNames; import org.apache.qpid.framing.*; import org.apache.qpid.properties.ConnectionStartProperties; import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.protocol.AMQMethodEvent; import org.apache.qpid.protocol.ServerProtocolEngine; import org.apache.qpid.server.configuration.BrokerProperties; import org.apache.qpid.server.connection.ConnectionPrincipal; @@ -67,15 +70,15 @@ import org.apache.qpid.server.message.InstanceProperties; import org.apache.qpid.server.message.ServerMessage; import org.apache.qpid.server.model.Broker; import org.apache.qpid.server.model.Port; +import org.apache.qpid.server.model.State; import org.apache.qpid.server.model.Transport; +import org.apache.qpid.server.model.port.AmqpPort; +import org.apache.qpid.server.protocol.AMQConnectionModel; import org.apache.qpid.server.protocol.AMQSessionModel; import org.apache.qpid.server.protocol.SessionModelListener; -import org.apache.qpid.server.protocol.v0_8.handler.ServerMethodDispatcherImpl; -import org.apache.qpid.server.protocol.v0_8.output.ProtocolOutputConverter; -import org.apache.qpid.server.protocol.v0_8.output.ProtocolOutputConverterRegistry; -import org.apache.qpid.server.protocol.v0_8.state.AMQState; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; +import org.apache.qpid.server.security.SubjectCreator; import org.apache.qpid.server.security.auth.AuthenticatedPrincipal; +import org.apache.qpid.server.security.auth.SubjectAuthenticationResult; import org.apache.qpid.server.stats.StatisticsCounter; import org.apache.qpid.server.util.Action; import org.apache.qpid.server.util.ConnectionScopedRuntimeException; @@ -86,7 +89,9 @@ import org.apache.qpid.transport.TransportException; import org.apache.qpid.transport.network.NetworkConnection; import org.apache.qpid.util.BytesDataOutput; -public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSession<AMQProtocolEngine> +public class AMQProtocolEngine implements ServerProtocolEngine, + AMQConnectionModel<AMQProtocolEngine, AMQChannel>, + ServerMethodProcessor<ServerChannelMethodProcessor> { private static final Logger _logger = Logger.getLogger(AMQProtocolEngine.class); @@ -94,6 +99,8 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi // channels. This value must be of the form 2^x - 1. private static final int CHANNEL_CACHE_SIZE = 0xff; private static final int REUSABLE_BYTE_BUFFER_CAPACITY = 65 * 1024; + public static final String BROKER_DEBUG_BINARY_DATA_LENGTH = "broker.debug.binaryDataLength"; + public static final int DEFAULT_DEBUG_BINARY_DATA_LENGTH = 80; private final Port<?> _port; private final long _creationTime; @@ -105,13 +112,12 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi private VirtualHostImpl<?,?,?> _virtualHost; - private final Map<Integer, AMQChannel<AMQProtocolEngine>> _channelMap = - new HashMap<Integer, AMQChannel<AMQProtocolEngine>>(); + private final Map<Integer, AMQChannel> _channelMap = + new HashMap<>(); private final CopyOnWriteArrayList<SessionModelListener> _sessionListeners = - new CopyOnWriteArrayList<SessionModelListener>(); + new CopyOnWriteArrayList<>(); - @SuppressWarnings("unchecked") - private final AMQChannel<AMQProtocolEngine>[] _cachedChannels = new AMQChannel[CHANNEL_CACHE_SIZE + 1]; + private final AMQChannel[] _cachedChannels = new AMQChannel[CHANNEL_CACHE_SIZE + 1]; /** * The channels that the latest call to {@link #received(ByteBuffer)} applied to. @@ -120,10 +126,8 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi * * Thread-safety: guarded by {@link #_receivedLock}. */ - private final Set<AMQChannel<AMQProtocolEngine>> _channelsForCurrentMessage = - new HashSet<AMQChannel<AMQProtocolEngine>>(); - - private final AMQStateManager _stateManager; + private final Set<AMQChannel> _channelsForCurrentMessage = + new HashSet<>(); private AMQDecoder _decoder; @@ -136,14 +140,13 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi /* AMQP Version for this session */ private ProtocolVersion _protocolVersion = ProtocolVersion.getLatestSupportedVersion(); - private MethodRegistry _methodRegistry = MethodRegistry.getMethodRegistry(_protocolVersion); + private final MethodRegistry _methodRegistry = new MethodRegistry(_protocolVersion); private final List<Action<? super AMQProtocolEngine>> _taskList = - new CopyOnWriteArrayList<Action<? super AMQProtocolEngine>>(); + new CopyOnWriteArrayList<>(); - private Map<Integer, Long> _closingChannelsList = new ConcurrentHashMap<Integer, Long>(); + private Map<Integer, Long> _closingChannelsList = new ConcurrentHashMap<>(); private ProtocolOutputConverter _protocolOutputConverter; private final Subject _authorizedSubject = new Subject(); - private MethodDispatcher _dispatcher; private final long _connectionID; private Object _reference = new Object(); @@ -177,6 +180,9 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi private boolean _authenticated; private boolean _compressionSupported; private int _messageCompressionThreshold; + private int _currentClassId; + private int _currentMethodId; + private int _binaryDataLimit; public AMQProtocolEngine(Broker broker, final NetworkConnection network, @@ -189,11 +195,12 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi _transport = transport; _maxNoOfChannels = broker.getConnection_sessionCountLimit(); _receivedLock = new ReentrantLock(); - _stateManager = new AMQStateManager(broker, this); - _decoder = new AMQDecoder(true, this); + _decoder = new BrokerDecoder(this); _connectionID = connectionId; _logSubject = new ConnectionLogSubject(this); - + _binaryDataLimit = _broker.getContextKeys(false).contains(BROKER_DEBUG_BINARY_DATA_LENGTH) + ? _broker.getContextValue(Integer.class, BROKER_DEBUG_BINARY_DATA_LENGTH) + : DEFAULT_DEBUG_BINARY_DATA_LENGTH; _authorizedSubject.getPrincipals().add(new ConnectionPrincipal(this)); runAsSubject(new PrivilegedAction<Void>() { @@ -303,28 +310,7 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi _receivedLock.lock(); try { - final ArrayList<AMQDataBlock> dataBlocks = _decoder.decodeBuffer(msg); - for (AMQDataBlock dataBlock : dataBlocks) - { - try - { - dataBlockReceived(dataBlock); - } - catch(AMQConnectionException e) - { - if(_logger.isDebugEnabled()) - { - _logger.debug("Caught AMQConnectionException but will simply stop processing data blocks - the connection should already be closed.", e); - } - break; - } - catch (AMQException e) - { - _logger.error("Unexpected exception when processing datablock", e); - closeProtocolSession(); - break; - } - } + _decoder.decodeBuffer(msg); receivedComplete(); } catch (ConnectionScopedRuntimeException e) @@ -366,7 +352,7 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi { RuntimeException exception = null; - for (AMQChannel<AMQProtocolEngine> channel : _channelsForCurrentMessage) + for (AMQChannel channel : _channelsForCurrentMessage) { try { @@ -391,112 +377,10 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi } } - /** - * Process the data block. - * If the message is for a channel it is added to {@link #_channelsForCurrentMessage}. - * - * @throws AMQConnectionException if unable to process the data block. In this case, - * the connection is already closed by the time the exception is thrown. If any other - * type of exception is thrown, the connection is not already closed. - */ - private void dataBlockReceived(AMQDataBlock message) throws AMQException - { - if (message instanceof ProtocolInitiation) - { - protocolInitiationReceived((ProtocolInitiation) message); - - } - else if (message instanceof AMQFrame) - { - AMQFrame frame = (AMQFrame) message; - frameReceived(frame); - - } - else - { - throw new AMQException("Unknown message type: " + message.getClass().getName() + ": " + message); - } - } - /** - * Handle the supplied frame. - * Adds this frame's channel to {@link #_channelsForCurrentMessage}. - * - * @throws AMQConnectionException if unable to process the data block. In this case, - * the connection is already closed by the time the exception is thrown. If any other - * type of exception is thrown, the connection is not already closed. - */ - private void frameReceived(AMQFrame frame) throws AMQException + void channelRequiresSync(final AMQChannel amqChannel) { - int channelId = frame.getChannel(); - AMQChannel<AMQProtocolEngine> amqChannel = _channelMap.get(channelId); - if(amqChannel != null) - { - // The _receivedLock is already acquired in the caller - // It is safe to add channel - _channelsForCurrentMessage.add(amqChannel); - } - else - { - // Not an error. The frame is probably a channel Open for this channel id, which - // does not require asynchronous work therefore its absence from - // _channelsForCurrentMessage is ok. - } - - AMQBody body = frame.getBodyFrame(); - - long startTime = 0; - String frameToString = null; - if (_logger.isDebugEnabled()) - { - startTime = System.currentTimeMillis(); - frameToString = frame.toString(); - _logger.debug("RECV: " + frame); - } - - // Check that this channel is not closing - if (channelAwaitingClosure(channelId)) - { - if ((frame.getBodyFrame() instanceof ChannelCloseOkBody)) - { - if (_logger.isInfoEnabled()) - { - _logger.info("Channel[" + channelId + "] awaiting closure - processing close-ok"); - } - } - else - { - // The channel has been told to close, we don't process any more frames until - // it's closed. - return; - } - } - - try - { - body.handle(channelId, this); - } - catch(AMQConnectionException e) - { - _logger.info(e.getMessage() + " whilst processing frame: " + body); - closeConnection(channelId, e); - throw e; - } - catch (AMQException e) - { - closeChannel(channelId, e.getErrorCode() == null ? AMQConstant.INTERNAL_ERROR : e.getErrorCode(), e.getMessage()); - throw e; - } - catch (TransportException e) - { - closeChannel(channelId, AMQConstant.CHANNEL_ERROR, e.getMessage()); - throw e; - } - - if(_logger.isDebugEnabled()) - { - _logger.debug("Frame handled in " + (System.currentTimeMillis() - startTime) + " ms. Frame: " + frameToString); - } + _channelsForCurrentMessage.add(amqChannel); } private synchronized void protocolInitiationReceived(ProtocolInitiation pi) @@ -615,87 +499,6 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi return buf; } - public void methodFrameReceived(int channelId, AMQMethodBody methodBody) - { - final AMQMethodEvent<AMQMethodBody> evt = new AMQMethodEvent<AMQMethodBody>(channelId, methodBody); - - try - { - try - { - boolean wasAnyoneInterested = _stateManager.methodReceived(evt); - - if (!wasAnyoneInterested) - { - throw new AMQNoMethodHandlerException(evt); - } - } - catch (AMQChannelException e) - { - if (getChannel(channelId) != null) - { - if (_logger.isInfoEnabled()) - { - _logger.info("Closing channel due to: " + e.getMessage()); - } - - writeFrame(e.getCloseFrame(channelId)); - closeChannel(channelId, e.getErrorCode() == null ? AMQConstant.INTERNAL_ERROR : e.getErrorCode(), e.getMessage()); - } - else - { - if (_logger.isDebugEnabled()) - { - _logger.debug("ChannelException occurred on non-existent channel:" + e.getMessage()); - } - - if (_logger.isInfoEnabled()) - { - _logger.info("Closing connection due to: " + e.getMessage()); - } - - AMQConnectionException ce = - evt.getMethod().getConnectionException(AMQConstant.CHANNEL_ERROR, - AMQConstant.CHANNEL_ERROR.getName().toString()); - - _logger.info(e.getMessage() + " whilst processing:" + methodBody); - closeConnection(channelId, ce); - } - } - catch (AMQConnectionException e) - { - _logger.info(e.getMessage() + " whilst processing:" + methodBody); - closeConnection(channelId, e); - } - } - catch (Exception e) - { - _logger.error("Unexpected exception while processing frame. Closing connection.", e); - - closeProtocolSession(); - } - } - - public void contentHeaderReceived(int channelId, ContentHeaderBody body) throws AMQException - { - - AMQChannel<AMQProtocolEngine> channel = getAndAssertChannel(channelId); - - channel.publishContentHeader(body); - - } - - public void contentBodyReceived(int channelId, ContentBody body) throws AMQException - { - AMQChannel<AMQProtocolEngine> channel = getAndAssertChannel(channelId); - - channel.publishContentBody(body); - } - - public void heartbeatBodyReceived(int channelId, HeartbeatBody body) - { - // NO - OP - } /** * Convenience method that writes a frame to the protocol session. Equivalent to calling @@ -735,28 +538,17 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi _contextKey = contextKey; } - public List<AMQChannel<AMQProtocolEngine>> getChannels() + public List<AMQChannel> getChannels() { synchronized (_channelMap) { - return new ArrayList<AMQChannel<AMQProtocolEngine>>(_channelMap.values()); - } - } - - public AMQChannel<AMQProtocolEngine> getAndAssertChannel(int channelId) throws AMQException - { - AMQChannel<AMQProtocolEngine> channel = getChannel(channelId); - if (channel == null) - { - throw new AMQException(AMQConstant.NOT_FOUND, "Channel not found with id:" + channelId); + return new ArrayList<>(_channelMap.values()); } - - return channel; } - public AMQChannel<AMQProtocolEngine> getChannel(int channelId) + public AMQChannel getChannel(int channelId) { - final AMQChannel<AMQProtocolEngine> channel = + final AMQChannel channel = ((channelId & CHANNEL_CACHE_SIZE) == channelId) ? _cachedChannels[channelId] : _channelMap.get(channelId); if ((channel == null) || channel.isClosing()) { @@ -773,38 +565,17 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi return !_closingChannelsList.isEmpty() && _closingChannelsList.containsKey(channelId); } - public void addChannel(AMQChannel<AMQProtocolEngine> channel) throws AMQException + public void addChannel(AMQChannel channel) { - if (_closed) - { - throw new AMQException("Session is closed"); - } - final int channelId = channel.getChannelId(); - if (_closingChannelsList.containsKey(channelId)) - { - throw new AMQException("Session is marked awaiting channel close"); - } - - if (_channelMap.size() == _maxNoOfChannels) - { - String errorMessage = - toString() + ": maximum number of channels has been reached (" + _maxNoOfChannels - + "); can't create channel"; - _logger.error(errorMessage); - throw new AMQException(AMQConstant.NOT_ALLOWED, errorMessage); - } - else + synchronized (_channelMap) { - synchronized (_channelMap) + _channelMap.put(channel.getChannelId(), channel); + sessionAdded(channel); + if(_blocking) { - _channelMap.put(channel.getChannelId(), channel); - sessionAdded(channel); - if(_blocking) - { - channel.block(); - } + channel.block(); } } @@ -830,7 +601,7 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi } } - public Long getMaximumNumberOfChannels() + public long getMaximumNumberOfChannels() { return _maxNoOfChannels; } @@ -840,52 +611,52 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi _maxNoOfChannels = value; } - /** - * Close a specific channel. This will remove any resources used by the channel, including: <ul><li>any queue - * subscriptions (this may in turn remove queues if they are auto delete</li> </ul> - * - * @param channelId id of the channel to close - * - * @throws IllegalArgumentException if the channel id is not valid - */ - @Override - public void closeChannel(int channelId) + + void closeChannel(AMQChannel channel) { - closeChannel(channelId, null, null); + closeChannel(channel, null, null, false); + } + + public void closeChannelAndWriteFrame(AMQChannel channel, AMQConstant cause, String message) + { + writeFrame(new AMQFrame(channel.getChannelId(), + getMethodRegistry().createChannelCloseBody(cause.getCode(), + AMQShortString.validValueOf(message), + _currentClassId, + _currentMethodId))); + closeChannel(channel, cause, message, true); } public void closeChannel(int channelId, AMQConstant cause, String message) { - final AMQChannel<AMQProtocolEngine> channel = getChannel(channelId); + final AMQChannel channel = getChannel(channelId); if (channel == null) { throw new IllegalArgumentException("Unknown channel id"); } - else + closeChannel(channel, cause, message, true); + } + + void closeChannel(AMQChannel channel, AMQConstant cause, String message, boolean mark) + { + int channelId = channel.getChannelId(); + try { - try + channel.close(cause, message); + if(mark) { - channel.close(cause, message); markChannelAwaitingCloseOk(channelId); } - finally - { - removeChannel(channelId); - } + } + finally + { + removeChannel(channelId); } } + public void closeChannelOk(int channelId) { - // todo QPID-847 - This is called from two locations ChannelCloseHandler and ChannelCloseOkHandler. - // When it is the CC_OK_Handler then it makes sense to remove the channel else we will leak memory. - // We do it from the Close Handler as we are sending the OK back to the client. - // While this is AMQP spec compliant. The Java client in the event of an IllegalArgumentException - // will send a close-ok.. Where we should call removeChannel. - // However, due to the poor exception handling on the client. The client-user will be notified of the - // InvalidArgument and if they then decide to close the session/connection then the there will be time - // for that to occur i.e. a new close method be sent before the exception handling can mark the session closed. - _closingChannelsList.remove(channelId); } @@ -901,7 +672,7 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi */ public void removeChannel(int channelId) { - AMQChannel<AMQProtocolEngine> session; + AMQChannel session; synchronized (_channelMap) { session = _channelMap.remove(channelId); @@ -937,7 +708,7 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi */ private void closeAllChannels() { - for (AMQChannel<AMQProtocolEngine> channel : getChannels()) + for (AMQChannel channel : getChannels()) { channel.close(); } @@ -952,7 +723,6 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi } /** This must be called when the session is _closed in order to free up any resources managed by the session. */ - @Override public void closeSession() { @@ -1042,13 +812,30 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi private void closeConnection(int channelId, AMQConnectionException e) { - try + + if (_logger.isInfoEnabled()) { - if (_logger.isInfoEnabled()) - { - _logger.info("Closing connection due to: " + e); - } + _logger.info("Closing connection due to: " + e); + } + closeConnection(channelId, e.getCloseFrame()); + } + + void closeConnection(AMQConstant errorCode, + String message, int channelId) + { + + if (_logger.isInfoEnabled()) + { + _logger.info("Closing connection due to: " + message); + } + closeConnection(channelId, new AMQFrame(0, new ConnectionCloseBody(getProtocolVersion(), errorCode.getCode(), AMQShortString.validValueOf(message), _currentClassId, _currentMethodId))); + } + + private void closeConnection(int channelId, AMQFrame frame) + { + try + { markChannelAwaitingCloseOk(channelId); closeSession(); } @@ -1056,8 +843,7 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi { try { - _stateManager.changeState(AMQState.CONNECTION_CLOSING); - writeFrame(e.getCloseFrame(channelId)); + writeFrame(frame); } finally { @@ -1068,23 +854,9 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi } - @Override public void closeProtocolSession() { _network.close(); - - try - { - _stateManager.changeState(AMQState.CONNECTION_CLOSED); - } - catch (ConnectionScopedRuntimeException e) - { - _logger.info(e.getMessage()); - } - catch (TransportException e) - { - _logger.info(e.getMessage()); - } } public String toString() @@ -1174,9 +946,8 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi private void setProtocolVersion(ProtocolVersion pv) { _protocolVersion = pv; - _methodRegistry = MethodRegistry.getMethodRegistry(_protocolVersion); - _protocolOutputConverter = ProtocolOutputConverterRegistry.getConverter(this); - _dispatcher = ServerMethodDispatcherImpl.createMethodDispatcher(_stateManager, _protocolVersion); + _methodRegistry.setProtocolVersion(_protocolVersion); + _protocolOutputConverter = new ProtocolOutputConverterImpl(this); } public byte getProtocolMajorVersion() @@ -1204,7 +975,7 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi return _virtualHost; } - public void setVirtualHost(VirtualHostImpl<?,?,?> virtualHost) throws AMQException + public void setVirtualHost(VirtualHostImpl<?,?,?> virtualHost) { _virtualHost = virtualHost; @@ -1285,11 +1056,6 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi return _methodRegistry; } - public MethodDispatcher getMethodDispatcher() - { - return _dispatcher; - } - public void closed() { try @@ -1303,14 +1069,10 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi closeProtocolSession(); } } - catch (ConnectionScopedRuntimeException e) + catch (ConnectionScopedRuntimeException | TransportException e) { _logger.error("Could not close protocol engine", e); } - catch (TransportException e) - { - _logger.error("Could not close protocol engine", e); - } } public void readerIdle() @@ -1351,9 +1113,11 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi { _logger.error("Exception caught in " + this + ", closing connection explicitly: " + throwable, throwable); - - MethodRegistry methodRegistry = MethodRegistry.getMethodRegistry(getProtocolVersion()); - ConnectionCloseBody closeBody = methodRegistry.createConnectionCloseBody(200, AMQShortString.validValueOf(throwable.getMessage()),0,0); + ConnectionCloseBody closeBody = _methodRegistry.createConnectionCloseBody(AMQConstant.INTERNAL_ERROR.getCode(), + AMQShortString.validValueOf( + throwable.getMessage()), + _currentClassId, + _currentMethodId); writeFrame(closeBody.generateFrame(0)); @@ -1374,11 +1138,6 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi } } - public void setSender(Sender<ByteBuffer> sender) - { - // Do nothing - } - public long getReadBytes() { return _readBytes; @@ -1460,7 +1219,7 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi return String.valueOf(getRemoteAddress()); } - public void closeSession(AMQChannel<AMQProtocolEngine> session, AMQConstant cause, String message) + public void closeSession(AMQChannel session, AMQConstant cause, String message) { int channelId = session.getChannelId(); closeChannel(channelId, cause, message); @@ -1470,7 +1229,7 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi methodRegistry.createChannelCloseBody( cause.getCode(), AMQShortString.validValueOf(message), - 0,0); + 0, 0); writeFrame(responseBody.generateFrame(channelId)); } @@ -1478,9 +1237,8 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi public void close(AMQConstant cause, String message) { closeConnection(0, new AMQConnectionException(cause, message, 0, 0, - getProtocolOutputConverter().getProtocolMajorVersion(), - getProtocolOutputConverter().getProtocolMinorVersion(), - null)); + getMethodRegistry(), + null)); } public void block() @@ -1490,7 +1248,7 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi if(!_blocking) { _blocking = true; - for(AMQChannel<AMQProtocolEngine> channel : _channelMap.values()) + for(AMQChannel channel : _channelMap.values()) { channel.block(); } @@ -1505,7 +1263,7 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi if(_blocking) { _blocking = false; - for(AMQChannel<AMQProtocolEngine> channel : _channelMap.values()) + for(AMQChannel channel : _channelMap.values()) { channel.unblock(); } @@ -1518,9 +1276,9 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi return _closed; } - public List<AMQChannel<AMQProtocolEngine>> getSessionModels() + public List<AMQChannel> getSessionModels() { - return new ArrayList<AMQChannel<AMQProtocolEngine>>(getChannels()); + return new ArrayList<>(getChannels()); } public LogSubject getLogSubject() @@ -1609,6 +1367,382 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi _deferFlush = deferFlush; } + @Override + public void receiveChannelOpen(final int channelId) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV[" + channelId + "] ChannelOpen"); + } + + // Protect the broker against out of order frame request. + if (_virtualHost == null) + { + closeConnection(AMQConstant.COMMAND_INVALID, + "Virtualhost has not yet been set. ConnectionOpen has not been called.", channelId); + } + else if(getChannel(channelId) != null || channelAwaitingClosure(channelId)) + { + closeConnection(AMQConstant.CHANNEL_ERROR, "Channel " + channelId + " already exists", channelId); + } + else if(channelId > getMaximumNumberOfChannels()) + { + closeConnection(AMQConstant.CHANNEL_ERROR, + "Channel " + channelId + " cannot be created as the max allowed channel id is " + + getMaximumNumberOfChannels(), + channelId); + } + else + { + _logger.info("Connecting to: " + _virtualHost.getName()); + + final AMQChannel channel = new AMQChannel(this, channelId, _virtualHost.getMessageStore()); + + addChannel(channel); + + ChannelOpenOkBody response; + + + response = getMethodRegistry().createChannelOpenOkBody(); + + + writeFrame(response.generateFrame(channelId)); + } + } + + @Override + public void receiveConnectionOpen(AMQShortString virtualHostName, + AMQShortString capabilities, + boolean insist) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV ConnectionOpen[" +" virtualHost: " + virtualHostName + " capabilities: " + capabilities + " insist: " + insist + " ]"); + } + + String virtualHostStr; + if ((virtualHostName != null) && virtualHostName.charAt(0) == '/') + { + virtualHostStr = virtualHostName.toString().substring(1); + } + else + { + virtualHostStr = virtualHostName == null ? null : virtualHostName.toString(); + } + + VirtualHostImpl virtualHost = ((AmqpPort)getPort()).getVirtualHost(virtualHostStr); + + if (virtualHost == null) + { + closeConnection(AMQConstant.NOT_FOUND, + "Unknown virtual host: '" + virtualHostName + "'",0); + + } + else + { + // Check virtualhost access + if (virtualHost.getState() != State.ACTIVE) + { + closeConnection(AMQConstant.CONNECTION_FORCED, + "Virtual host '" + virtualHost.getName() + "' is not active",0); + + } + else + { + setVirtualHost(virtualHost); + try + { + virtualHost.getSecurityManager().authoriseCreateConnection(this); + if (getContextKey() == null) + { + setContextKey(new AMQShortString(Long.toString(System.currentTimeMillis()))); + } + + MethodRegistry methodRegistry = getMethodRegistry(); + AMQMethodBody responseBody = methodRegistry.createConnectionOpenOkBody(virtualHostName); + + writeFrame(responseBody.generateFrame(0)); + } + catch (AccessControlException e) + { + closeConnection(AMQConstant.ACCESS_REFUSED, e.getMessage(),0); + } + } + } + } + + @Override + public void receiveConnectionClose(final int replyCode, + final AMQShortString replyText, + final int classId, + final int methodId) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV ConnectionClose[" +" replyCode: " + replyCode + " replyText: " + replyText + " classId: " + classId + " methodId: " + methodId + " ]"); + } + + if (_logger.isInfoEnabled()) + { + _logger.info("ConnectionClose received with reply code/reply text " + replyCode + "/" + + replyText + " for " + this); + } + try + { + closeSession(); + } + catch (Exception e) + { + _logger.error("Error closing protocol session: " + e, e); + } + + MethodRegistry methodRegistry = getMethodRegistry(); + ConnectionCloseOkBody responseBody = methodRegistry.createConnectionCloseOkBody(); + writeFrame(responseBody.generateFrame(0)); + + closeProtocolSession(); + + } + + @Override + public void receiveConnectionCloseOk() + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV ConnectionCloseOk"); + } + + _logger.info("Received Connection-close-ok"); + + try + { + closeSession(); + } + catch (Exception e) + { + _logger.error("Error closing protocol session: " + e, e); + } + } + + @Override + public void receiveConnectionSecureOk(final byte[] response) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV ConnectionSecureOk[ response: ******** ] "); + } + + Broker<?> broker = getBroker(); + + SubjectCreator subjectCreator = getSubjectCreator(); + + SaslServer ss = getSaslServer(); + if (ss == null) + { + closeConnection(AMQConstant.INTERNAL_ERROR, "No SASL context set up in session",0 ); + } + MethodRegistry methodRegistry = getMethodRegistry(); + SubjectAuthenticationResult authResult = subjectCreator.authenticate(ss, response); + switch (authResult.getStatus()) + { + case ERROR: + Exception cause = authResult.getCause(); + + _logger.info("Authentication failed:" + (cause == null ? "" : cause.getMessage())); + + closeConnection(AMQConstant.NOT_ALLOWED, "Authentication failed",0); + + disposeSaslServer(); + break; + case SUCCESS: + if (_logger.isInfoEnabled()) + { + _logger.info("Connected as: " + authResult.getSubject()); + } + + int frameMax = broker.getContextValue(Integer.class, Broker.BROKER_FRAME_SIZE); + + if (frameMax <= 0) + { + frameMax = Integer.MAX_VALUE; + } + + ConnectionTuneBody tuneBody = + methodRegistry.createConnectionTuneBody(broker.getConnection_sessionCountLimit(), + frameMax, + broker.getConnection_heartBeatDelay()); + writeFrame(tuneBody.generateFrame(0)); + setAuthorizedSubject(authResult.getSubject()); + disposeSaslServer(); + break; + case CONTINUE: + + ConnectionSecureBody + secureBody = methodRegistry.createConnectionSecureBody(authResult.getChallenge()); + writeFrame(secureBody.generateFrame(0)); + } + } + + + private void disposeSaslServer() + { + SaslServer ss = getSaslServer(); + if (ss != null) + { + setSaslServer(null); + try + { + ss.dispose(); + } + catch (SaslException e) + { + _logger.error("Error disposing of Sasl server: " + e); + } + } + } + + @Override + public void receiveConnectionStartOk(final FieldTable clientProperties, + final AMQShortString mechanism, + final byte[] response, + final AMQShortString locale) + { + if (_logger.isDebugEnabled()) + { + _logger.debug("RECV ConnectionStartOk[" + + " clientProperties: " + + clientProperties + + " mechanism: " + + mechanism + + " response: ********" + + " locale: " + + locale + + " ]"); + } + + Broker<?> broker = getBroker(); + + _logger.info("SASL Mechanism selected: " + mechanism); + _logger.info("Locale selected: " + locale); + + SubjectCreator subjectCreator = getSubjectCreator(); + SaslServer ss = null; + try + { + ss = subjectCreator.createSaslServer(String.valueOf(mechanism), + getLocalFQDN(), + getPeerPrincipal()); + + if (ss == null) + { + closeConnection(AMQConstant.RESOURCE_ERROR, "Unable to create SASL Server:" + mechanism, 0); + + } + else + { + //save clientProperties + setClientProperties(clientProperties); + + setSaslServer(ss); + + final SubjectAuthenticationResult authResult = subjectCreator.authenticate(ss, response); + + MethodRegistry methodRegistry = getMethodRegistry(); + + switch (authResult.getStatus()) + { + case ERROR: + Exception cause = authResult.getCause(); + + _logger.info("Authentication failed:" + (cause == null ? "" : cause.getMessage())); + + closeConnection(AMQConstant.NOT_ALLOWED, "Authentication failed", 0); + + disposeSaslServer(); + break; + + case SUCCESS: + if (_logger.isInfoEnabled()) + { + _logger.info("Connected as: " + authResult.getSubject()); + } + setAuthorizedSubject(authResult.getSubject()); + + int frameMax = broker.getContextValue(Integer.class, Broker.BROKER_FRAME_SIZE); + + if (frameMax <= 0) + { + frameMax = Integer.MAX_VALUE; + } + + ConnectionTuneBody + tuneBody = + methodRegistry.createConnectionTuneBody(broker.getConnection_sessionCountLimit(), + frameMax, + broker.getConnection_heartBeatDelay()); + writeFrame(tuneBody.generateFrame(0)); + break; + case CONTINUE: + ConnectionSecureBody + secureBody = methodRegistry.createConnectionSecureBody(authResult.getChallenge()); + writeFrame(secureBody.generateFrame(0)); + } + } + } + catch (SaslException e) + { + disposeSaslServer(); + closeConnection(AMQConstant.INTERNAL_ERROR, "SASL error: " + e, 0); + } + } + + @Override + public void receiveConnectionTuneOk(final int channelMax, final long frameMax, final int heartbeat) + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV ConnectionTuneOk[" +" channelMax: " + channelMax + " frameMax: " + frameMax + " heartbeat: " + heartbeat + " ]"); + } + + initHeartbeats(heartbeat); + + int brokerFrameMax = getBroker().getContextValue(Integer.class, Broker.BROKER_FRAME_SIZE); + if (brokerFrameMax <= 0) + { + brokerFrameMax = Integer.MAX_VALUE; + } + + if (frameMax > (long) brokerFrameMax) + { + closeConnection(AMQConstant.SYNTAX_ERROR, + "Attempt to set max frame size to " + frameMax + + " greater than the broker will allow: " + + brokerFrameMax, 0); + } + else if (frameMax > 0 && frameMax < AMQConstant.FRAME_MIN_SIZE.getCode()) + { + closeConnection(AMQConstant.SYNTAX_ERROR, + "Attempt to set max frame size to " + frameMax + + " which is smaller than the specification defined minimum: " + + AMQConstant.FRAME_MIN_SIZE.getCode(), 0); + } + else + { + int calculatedFrameMax = frameMax == 0 ? brokerFrameMax : (int) frameMax; + setMaxFrameSize(calculatedFrameMax); + + //0 means no implied limit, except that forced by protocol limitations (0xFFFF) + setMaximumNumberOfChannels( ((channelMax == 0l) || (channelMax > 0xFFFFL)) + ? 0xFFFFL + : channelMax); + } + } + + public int getBinaryDataLimit() + { + return _binaryDataLimit; + } + public final class WriteDeliverMethod implements ClientDeliveryMethod { @@ -1656,24 +1790,31 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi return _lastWriteTime.get(); } - @Override public boolean isCloseWhenNoRoute() { return _closeWhenNoRoute; } - @Override public boolean isCompressionSupported() { return _compressionSupported && _broker.isMessageCompressionEnabled(); } - @Override public int getMessageCompressionThreshold() { return _messageCompressionThreshold; } + public Broker<?> getBroker() + { + return _broker; + } + + public SubjectCreator getSubjectCreator() + { + return _broker.getSubjectCreator(getLocalAddress(), getTransport().isSecure()); + } + public EventLogger getEventLogger() { if(_virtualHost != null) @@ -1685,4 +1826,72 @@ public class AMQProtocolEngine implements ServerProtocolEngine, AMQProtocolSessi return _broker.getEventLogger(); } } + + @Override + public ServerChannelMethodProcessor getChannelMethodProcessor(final int channelId) + { + ServerChannelMethodProcessor channelMethodProcessor = getChannel(channelId); + if(channelMethodProcessor == null) + { + channelMethodProcessor = (ServerChannelMethodProcessor) Proxy.newProxyInstance(ServerMethodDispatcher.class.getClassLoader(), + new Class[] { ServerChannelMethodProcessor.class }, new InvocationHandler() + { + @Override + public Object invoke(final Object proxy, final Method method, final Object[] args) + throws Throwable + { + if(method.getName().startsWith("receive")) + { + closeConnection(AMQConstant.CHANNEL_ERROR, + "Unknown channel id: " + channelId, + channelId); + return null; + } + else if(method.getName().equals("ignoreAllButCloseOk")) + { + return false; + } + return null; + } + }); + } + return channelMethodProcessor; + } + + @Override + public void receiveHeartbeat() + { + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV Heartbeat"); + } + + // No op + } + + @Override + public void receiveProtocolHeader(final ProtocolInitiation protocolInitiation) + { + + if(_logger.isDebugEnabled()) + { + _logger.debug("RECV ProtocolHeader [" + protocolInitiation + " ]"); + } + + protocolInitiationReceived(protocolInitiation); + } + + @Override + public void setCurrentMethod(final int classId, final int methodId) + { + _currentClassId = classId; + _currentMethodId = methodId; + } + + @Override + public boolean ignoreAllButCloseOk() + { + return _closing.get(); + } + } diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolSession.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolSession.java deleted file mode 100644 index 587669dadc..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQProtocolSession.java +++ /dev/null @@ -1,217 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8; - -import java.net.SocketAddress; -import java.security.Principal; -import java.util.List; -import java.util.concurrent.locks.Lock; - -import javax.security.auth.Subject; -import javax.security.sasl.SaslServer; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.FieldTable; -import org.apache.qpid.framing.MethodDispatcher; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.protocol.AMQVersionAwareProtocolSession; -import org.apache.qpid.server.protocol.AMQConnectionModel; -import org.apache.qpid.server.protocol.v0_8.output.ProtocolOutputConverter; -import org.apache.qpid.server.security.AuthorizationHolder; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - - -public interface AMQProtocolSession<T extends AMQProtocolSession<T>> - extends AMQVersionAwareProtocolSession, AuthorizationHolder, AMQConnectionModel<T,AMQChannel<T>> -{ - long getSessionID(); - - void setMaxFrameSize(int frameMax); - - long getMaxFrameSize(); - - boolean isClosing(); - - void flushBatched(); - - void setDeferFlush(boolean defer); - - ClientDeliveryMethod createDeliveryMethod(int channelId); - - long getLastReceivedTime(); - - /** - * Return the local socket address for the connection - * - * @return the socket address - */ - SocketAddress getLocalAddress(); - - /** - * Get the context key associated with this session. Context key is described in the AMQ protocol specification (RFC - * 6). - * - * @return the context key - */ - AMQShortString getContextKey(); - - /** - * Set the context key associated with this session. Context key is described in the AMQ protocol specification (RFC - * 6). - * - * @param contextKey the context key - */ - void setContextKey(AMQShortString contextKey); - - /** - * Get the channel for this session associated with the specified id. A channel id is unique per connection (i.e. - * per session). - * - * @param channelId the channel id which must be valid - * - * @return null if no channel exists, the channel otherwise - */ - AMQChannel<T> getChannel(int channelId); - - /** - * Associate a channel with this session. - * - * @param channel the channel to associate with this session. It is an error to associate the same channel with more - * than one session but this is not validated. - */ - void addChannel(AMQChannel<T> channel) throws AMQException; - - /** - * Close a specific channel. This will remove any resources used by the channel, including: <ul><li>any queue - * subscriptions (this may in turn remove queues if they are auto delete</li> </ul> - * - * @param channelId id of the channel to close - * - * @throws org.apache.qpid.AMQException if an error occurs closing the channel - * @throws IllegalArgumentException if the channel id is not valid - */ - void closeChannel(int channelId) throws AMQException; - - void closeChannel(int channelId, AMQConstant cause, String message) throws AMQException; - - /** - * Marks the specific channel as closed. This will release the lock for that channel id so a new channel can be - * created on that id. - * - * @param channelId id of the channel to close - */ - void closeChannelOk(int channelId); - - /** - * Check to see if this chanel is closing - * - * @param channelId id to check - * @return boolean with state of channel awaiting closure - */ - boolean channelAwaitingClosure(int channelId); - - /** - * Remove a channel from the session but do not close it. - * - * @param channelId - */ - void removeChannel(int channelId); - - /** - * Initialise heartbeats on the session. - * - * @param delay delay in seconds (not ms) - */ - void initHeartbeats(int delay); - - /** This must be called when the session is _closed in order to free up any resources managed by the session. */ - void closeSession(); - - void closeProtocolSession(); - - /** @return a key that uniquely identifies this session */ - Object getKey(); - - /** - * Get the fully qualified domain name of the local address to which this session is bound. Since some servers may - * be bound to multiple addresses this could vary depending on the acceptor this session was created from. - * - * @return a String FQDN - */ - String getLocalFQDN(); - - /** @return the sasl server that can perform authentication for this session. */ - SaslServer getSaslServer(); - - /** - * Set the sasl server that is to perform authentication for this session. - * - * @param saslServer - */ - void setSaslServer(SaslServer saslServer); - - void setClientProperties(FieldTable clientProperties); - - Object getReference(); - - VirtualHostImpl<?,?,?> getVirtualHost(); - - void setVirtualHost(VirtualHostImpl<?,?,?> virtualHost) throws AMQException; - - public ProtocolOutputConverter getProtocolOutputConverter(); - - void setAuthorizedSubject(Subject authorizedSubject); - - public java.net.SocketAddress getRemoteAddress(); - - public MethodRegistry getMethodRegistry(); - - public MethodDispatcher getMethodDispatcher(); - - String getClientVersion(); - - long getLastIoTime(); - - long getWrittenBytes(); - - Long getMaximumNumberOfChannels(); - - void setMaximumNumberOfChannels(Long value); - - List<AMQChannel<T>> getChannels(); - - public Principal getPeerPrincipal(); - - Lock getReceivedLock(); - - /** - * Used for 0-8/0-9/0-9-1 connections to choose to close - * the connection when a transactional session receives a 'mandatory' message which - * can't be routed rather than returning the message. - */ - boolean isCloseWhenNoRoute(); - - boolean isCompressionSupported(); - - int getMessageCompressionThreshold(); -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/BrokerDecoder.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/BrokerDecoder.java new file mode 100644 index 0000000000..6497a04946 --- /dev/null +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/BrokerDecoder.java @@ -0,0 +1,117 @@ +/* + * + * 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.protocol.v0_8; + +import java.io.IOException; +import java.security.PrivilegedActionException; +import java.security.PrivilegedExceptionAction; + +import javax.security.auth.Subject; + +import org.apache.log4j.Logger; + +import org.apache.qpid.codec.MarkableDataInput; +import org.apache.qpid.codec.ServerDecoder; +import org.apache.qpid.framing.AMQFrameDecodingException; +import org.apache.qpid.server.util.ServerScopedRuntimeException; + +public class BrokerDecoder extends ServerDecoder +{ + private static final Logger _logger = Logger.getLogger(BrokerDecoder.class); + private final AMQProtocolEngine _connection; + /** + * Creates a new AMQP decoder. + * + * @param connection + */ + public BrokerDecoder(final AMQProtocolEngine connection) + { + super(connection); + _connection = connection; + } + + @Override + protected void processFrame(final int channelId, final byte type, final long bodySize, final MarkableDataInput in) + throws AMQFrameDecodingException, IOException + { + long startTime = 0; + if (_logger.isDebugEnabled()) + { + startTime = System.currentTimeMillis(); + } + Subject subject; + AMQChannel channel = _connection.getChannel(channelId); + if(channel == null) + { + subject = _connection.getSubject(); + } + else + { + _connection.channelRequiresSync(channel); + + subject = channel.getSubject(); + } + try + { + Subject.doAs(subject, new PrivilegedExceptionAction<Object>() + { + @Override + public Void run() throws IOException, AMQFrameDecodingException + { + doProcessFrame(channelId, type, bodySize, in); + return null; + } + }); + if(_logger.isDebugEnabled()) + { + _logger.debug("Frame handled in " + (System.currentTimeMillis() - startTime) + " ms."); + } + + } + catch (PrivilegedActionException e) + { + Throwable cause = e.getCause(); + if(cause instanceof IOException) + { + throw (IOException) cause; + } + else if(cause instanceof AMQFrameDecodingException) + { + throw (AMQFrameDecodingException) cause; + } + else if(cause instanceof RuntimeException) + { + throw (RuntimeException) cause; + } + else throw new ServerScopedRuntimeException(cause); + } + + } + + + private void doProcessFrame(final int channelId, final byte type, final long bodySize, final MarkableDataInput in) + throws AMQFrameDecodingException, IOException + { + super.processFrame(channelId, type, bodySize, in); + + } + +} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpParseException.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ConsumerTagInUseException.java index 3f3d4611fc..25c1462060 100644 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpParseException.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ConsumerTagInUseException.java @@ -7,9 +7,9 @@ * 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 @@ -18,13 +18,12 @@ * under the License. * */ -package org.apache.qpid.gentools; +package org.apache.qpid.server.protocol.v0_8; -@SuppressWarnings("serial") -public class AmqpParseException extends RuntimeException +public class ConsumerTagInUseException extends Exception { - public AmqpParseException(String msg) + public ConsumerTagInUseException(final String message) { - super(msg); + super(message); } } diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ConsumerTarget_0_8.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ConsumerTarget_0_8.java index acb74c99e6..43982db2fd 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ConsumerTarget_0_8.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ConsumerTarget_0_8.java @@ -39,7 +39,6 @@ import org.apache.qpid.server.message.MessageInstance; import org.apache.qpid.server.message.MessageReference; import org.apache.qpid.server.message.ServerMessage; import org.apache.qpid.server.protocol.AMQSessionModel; -import org.apache.qpid.server.protocol.v0_8.output.ProtocolOutputConverter; import org.apache.qpid.server.queue.QueueEntry; import org.apache.qpid.server.txn.AutoCommitTransaction; import org.apache.qpid.server.txn.ServerTransaction; @@ -80,7 +79,7 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen public static ConsumerTarget_0_8 createBrowserTarget(AMQChannel channel, AMQShortString consumerTag, FieldTable filters, - FlowCreditManager creditManager) throws AMQException + FlowCreditManager creditManager) { return new BrowserConsumer(channel, consumerTag, filters, creditManager, channel.getClientDeliveryMethod(), channel.getRecordDeliveryMethod()); } @@ -90,7 +89,7 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen final FieldTable filters, final FlowCreditManager creditManager, final ClientDeliveryMethod deliveryMethod, - final RecordDeliveryMethod recordMethod) throws AMQException + final RecordDeliveryMethod recordMethod) { return new GetNoAckConsumer(channel, consumerTag, filters, creditManager, deliveryMethod, recordMethod); } @@ -107,7 +106,6 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen FlowCreditManager creditManager, ClientDeliveryMethod deliveryMethod, RecordDeliveryMethod recordMethod) - throws AMQException { super(channel, consumerTag, filters, creditManager, deliveryMethod, recordMethod); @@ -148,7 +146,7 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen public static ConsumerTarget_0_8 createNoAckTarget(AMQChannel channel, AMQShortString consumerTag, FieldTable filters, - FlowCreditManager creditManager) throws AMQException + FlowCreditManager creditManager) { return new NoAckConsumer(channel, consumerTag, filters, creditManager, channel.getClientDeliveryMethod(), channel.getRecordDeliveryMethod()); } @@ -171,7 +169,6 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen FlowCreditManager creditManager, ClientDeliveryMethod deliveryMethod, RecordDeliveryMethod recordMethod) - throws AMQException { super(channel, consumerTag, filters, creditManager, deliveryMethod, recordMethod); @@ -207,7 +204,7 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen long size; synchronized (getChannel()) { - getChannel().getProtocolSession().setDeferFlush(batch); + getChannel().getConnection().setDeferFlush(batch); long deliveryTag = getChannel().getNextDeliveryTag(); size = sendToClient(consumer, message, props, deliveryTag); @@ -249,7 +246,6 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen FlowCreditManager creditManager, ClientDeliveryMethod deliveryMethod, RecordDeliveryMethod recordMethod) - throws AMQException { super(channel, consumerTag, filters, creditManager, deliveryMethod, recordMethod); } @@ -265,7 +261,6 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen public static ConsumerTarget_0_8 createAckTarget(AMQChannel channel, AMQShortString consumerTag, FieldTable filters, FlowCreditManager creditManager) - throws AMQException { return new AckConsumer(channel,consumerTag,filters,creditManager, channel.getClientDeliveryMethod(), channel.getRecordDeliveryMethod()); } @@ -276,7 +271,6 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen FlowCreditManager creditManager, ClientDeliveryMethod deliveryMethod, RecordDeliveryMethod recordMethod) - throws AMQException { return new AckConsumer(channel,consumerTag,filters,creditManager, deliveryMethod, recordMethod); } @@ -288,7 +282,6 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen FlowCreditManager creditManager, ClientDeliveryMethod deliveryMethod, RecordDeliveryMethod recordMethod) - throws AMQException { super(channel, consumerTag, filters, creditManager, deliveryMethod, recordMethod); } @@ -308,7 +301,7 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen synchronized (getChannel()) { - getChannel().getProtocolSession().setDeferFlush(batch); + getChannel().getConnection().setDeferFlush(batch); long deliveryTag = getChannel().getNextDeliveryTag(); addUnacknowledgedMessage(entry); @@ -346,7 +339,6 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen FlowCreditManager creditManager, ClientDeliveryMethod deliveryMethod, RecordDeliveryMethod recordMethod) - throws AMQException { super(State.ACTIVE); @@ -474,9 +466,9 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen return _consumerTag; } - public AMQProtocolSession getProtocolSession() + public AMQProtocolEngine getProtocolSession() { - return _channel.getProtocolSession(); + return _channel.getConnection(); } public void restoreCredit(final ServerMessage message) @@ -525,7 +517,7 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen public void confirmAutoClose() { - ProtocolOutputConverter converter = getChannel().getProtocolSession().getProtocolOutputConverter(); + ProtocolOutputConverter converter = getChannel().getConnection().getProtocolOutputConverter(); converter.confirmConsumerAutoClose(getChannel().getChannelId(), getConsumerTag()); } @@ -540,9 +532,9 @@ public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implemen public void flushBatched() { - _channel.getProtocolSession().setDeferFlush(false); + _channel.getConnection().setDeferFlush(false); - _channel.getProtocolSession().flushBatched(); + _channel.getConnection().flushBatched(); } protected void addUnacknowledgedMessage(MessageInstance entry) diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ExtractResendAndRequeue.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ExtractResendAndRequeue.java index 7a2fdb05fc..d61eb1b223 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ExtractResendAndRequeue.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ExtractResendAndRequeue.java @@ -20,14 +20,13 @@ */ package org.apache.qpid.server.protocol.v0_8; +import java.util.Map; + import org.apache.log4j.Logger; -import org.apache.qpid.AMQException; import org.apache.qpid.server.consumer.ConsumerImpl; import org.apache.qpid.server.message.MessageInstance; -import java.util.Map; - public class ExtractResendAndRequeue implements UnacknowledgedMessageMap.Visitor { private static final Logger _log = Logger.getLogger(ExtractResendAndRequeue.class); @@ -45,7 +44,7 @@ public class ExtractResendAndRequeue implements UnacknowledgedMessageMap.Visitor _msgToResend = msgToResend; } - public boolean callback(final long deliveryTag, MessageInstance message) throws AMQException + public boolean callback(final long deliveryTag, MessageInstance message) { message.setRedelivered(); diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/IncomingMessage.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/IncomingMessage.java index 80c4c77b65..d966e9c9c6 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/IncomingMessage.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/IncomingMessage.java @@ -20,16 +20,15 @@ */ package org.apache.qpid.server.protocol.v0_8; -import org.apache.qpid.AMQException; +import java.util.ArrayList; +import java.util.List; + import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.ContentBody; import org.apache.qpid.framing.ContentHeaderBody; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.message.MessageDestination; -import java.util.ArrayList; -import java.util.List; - public class IncomingMessage { @@ -58,7 +57,7 @@ public class IncomingMessage return _messagePublishInfo; } - public void addContentBodyFrame(final ContentBody contentChunk) throws AMQException + public void addContentBodyFrame(final ContentBody contentChunk) { _bodyLengthReceived += contentChunk.getSize(); _contentChunks.add(contentChunk); @@ -94,7 +93,7 @@ public class IncomingMessage _messageDestination = e; } - public int getBodyCount() throws AMQException + public int getBodyCount() { return _contentChunks.size(); } diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/MessageConverter_Internal_to_v0_8.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/MessageConverter_Internal_to_v0_8.java index 0f383c5ff0..55746dfa95 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/MessageConverter_Internal_to_v0_8.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/MessageConverter_Internal_to_v0_8.java @@ -33,7 +33,7 @@ import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.BasicContentHeaderProperties; import org.apache.qpid.framing.ContentHeaderBody; import org.apache.qpid.framing.FieldTable; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.message.internal.InternalMessage; import org.apache.qpid.server.plugin.MessageConverter; import org.apache.qpid.server.plugin.PluggableService; @@ -135,38 +135,10 @@ public class MessageConverter_Internal_to_v0_8 implements MessageConverter<Inter private MessageMetaData convertMetaData(final InternalMessage serverMsg, final String bodyMimeType, final int size) { - MessagePublishInfo publishInfo = new MessagePublishInfo() - { - @Override - public AMQShortString getExchange() - { - return AMQShortString.EMPTY_STRING; - } - - @Override - public void setExchange(final AMQShortString amqShortString) - { - throw new UnsupportedOperationException(); - } - - @Override - public boolean isImmediate() - { - return false; - } - - @Override - public boolean isMandatory() - { - return false; - } - - @Override - public AMQShortString getRoutingKey() - { - return AMQShortString.valueOf(serverMsg.getInitialRoutingAddress()); - } - }; + MessagePublishInfo publishInfo = new MessagePublishInfo(AMQShortString.EMPTY_STRING, + false, + false, + AMQShortString.valueOf(serverMsg.getInitialRoutingAddress())); final BasicContentHeaderProperties props = new BasicContentHeaderProperties(); @@ -191,7 +163,7 @@ public class MessageConverter_Internal_to_v0_8 implements MessageConverter<Inter props.setHeaders(FieldTable.convertToFieldTable(headerProps)); - final ContentHeaderBody chb = new ContentHeaderBody(props, BASIC_CLASS_ID); + final ContentHeaderBody chb = new ContentHeaderBody(props); chb.setBodySize(size); return new MessageMetaData(publishInfo, chb, serverMsg.getArrivalTime()); } diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/MessageMetaData.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/MessageMetaData.java index fd7fb9ca80..6b2902d0fa 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/MessageMetaData.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/MessageMetaData.java @@ -20,8 +20,13 @@ */ package org.apache.qpid.server.protocol.v0_8; +import java.io.DataInputStream; +import java.io.DataOutputStream; +import java.io.IOException; +import java.nio.ByteBuffer; import java.util.Collection; -import org.apache.qpid.AMQException; +import java.util.Set; + import org.apache.qpid.framing.AMQFrameDecodingException; import org.apache.qpid.framing.AMQProtocolVersionException; import org.apache.qpid.framing.AMQShortString; @@ -29,7 +34,7 @@ import org.apache.qpid.framing.BasicContentHeaderProperties; import org.apache.qpid.framing.ContentHeaderBody; import org.apache.qpid.framing.EncodingUtils; import org.apache.qpid.framing.FieldTable; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.message.AMQMessageHeader; import org.apache.qpid.server.plugin.MessageMetaDataType; import org.apache.qpid.server.store.StorableMessageMetaData; @@ -37,12 +42,6 @@ import org.apache.qpid.server.util.ByteBufferOutputStream; import org.apache.qpid.server.util.ConnectionScopedRuntimeException; import org.apache.qpid.util.ByteBufferInputStream; -import java.io.DataInputStream; -import java.io.DataOutputStream; -import java.io.IOException; -import java.nio.ByteBuffer; -import java.util.Set; - /** * Encapsulates a publish body and a content header. In the context of the message store these are treated as a * single unit. @@ -170,33 +169,11 @@ public class MessageMetaData implements StorableMessageMetaData long arrivalTime = EncodingUtils.readLong(dais); MessagePublishInfo publishBody = - new MessagePublishInfo() - { - - public AMQShortString getExchange() - { - return exchange; - } - - public void setExchange(AMQShortString exchange) - { - } - - public boolean isImmediate() - { - return (flags & IMMEDIATE_FLAG) != 0; - } - - public boolean isMandatory() - { - return (flags & MANDATORY_FLAG) != 0; - } - - public AMQShortString getRoutingKey() - { - return routingKey; - } - }; + new MessagePublishInfo(exchange, + (flags & IMMEDIATE_FLAG) != 0, + (flags & MANDATORY_FLAG) != 0, + routingKey); + return new MessageMetaData(publishBody, chb, arrivalTime); } catch (IOException e) diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/output/ProtocolOutputConverter.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ProtocolOutputConverter.java index 4ee5cbc17d..69f71f14a9 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/output/ProtocolOutputConverter.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ProtocolOutputConverter.java @@ -24,26 +24,20 @@ * Supported AMQP versions: * 8-0 */ -package org.apache.qpid.server.protocol.v0_8.output; +package org.apache.qpid.server.protocol.v0_8; import org.apache.qpid.framing.AMQDataBlock; import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.ContentHeaderBody; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.message.InstanceProperties; import org.apache.qpid.server.message.MessageContentSource; import org.apache.qpid.server.message.ServerMessage; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; public interface ProtocolOutputConverter { void confirmConsumerAutoClose(int channelId, AMQShortString consumerTag); - interface Factory - { - ProtocolOutputConverter newInstance(AMQProtocolSession session); - } - long writeDeliver(final ServerMessage msg, final InstanceProperties props, int channelId, long deliveryTag, @@ -55,10 +49,6 @@ public interface ProtocolOutputConverter long deliveryTag, int queueSize); - byte getProtocolMinorVersion(); - - byte getProtocolMajorVersion(); - void writeReturn(MessagePublishInfo messagePublishInfo, ContentHeaderBody header, MessageContentSource msgContent, int channelId, int replyCode, AMQShortString replyText); void writeFrame(AMQDataBlock block); diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/output/ProtocolOutputConverterImpl.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ProtocolOutputConverterImpl.java index 46a575e934..b616aab126 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/output/ProtocolOutputConverterImpl.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ProtocolOutputConverterImpl.java @@ -18,7 +18,7 @@ * under the License. * */ -package org.apache.qpid.server.protocol.v0_8.output; +package org.apache.qpid.server.protocol.v0_8; import java.io.DataOutput; import java.io.IOException; @@ -35,38 +35,28 @@ import org.apache.qpid.framing.BasicContentHeaderProperties; import org.apache.qpid.framing.BasicGetOkBody; import org.apache.qpid.framing.BasicReturnBody; import org.apache.qpid.framing.ContentHeaderBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.protocol.AMQVersionAwareProtocolSession; import org.apache.qpid.server.message.InstanceProperties; import org.apache.qpid.server.message.MessageContentSource; import org.apache.qpid.server.message.ServerMessage; import org.apache.qpid.server.plugin.MessageConverter; import org.apache.qpid.server.protocol.MessageConverterRegistry; -import org.apache.qpid.server.protocol.v0_8.AMQMessage; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; import org.apache.qpid.util.GZIPUtils; -class ProtocolOutputConverterImpl implements ProtocolOutputConverter +public class ProtocolOutputConverterImpl implements ProtocolOutputConverter { private static final int BASIC_CLASS_ID = 60; - private final MethodRegistry _methodRegistry; - private final AMQProtocolSession _protocolSession; + private final AMQProtocolEngine _connection; private static final AMQShortString GZIP_ENCODING = AMQShortString.valueOf(GZIPUtils.GZIP_CONTENT_ENCODING); - ProtocolOutputConverterImpl(AMQProtocolSession session, MethodRegistry methodRegistry) + public ProtocolOutputConverterImpl(AMQProtocolEngine connection) { - _protocolSession = session; - _methodRegistry = methodRegistry; + _connection = connection; } - public AMQProtocolSession getProtocolSession() - { - return _protocolSession; - } - public long writeDeliver(final ServerMessage m, final InstanceProperties props, int channelId, long deliveryTag, @@ -86,7 +76,7 @@ class ProtocolOutputConverterImpl implements ProtocolOutputConverter } else { - return getMessageConverter(serverMessage).convert(serverMessage, _protocolSession.getVirtualHost()); + return getMessageConverter(serverMessage).convert(serverMessage, _connection.getVirtualHost()); } } @@ -109,7 +99,7 @@ class ProtocolOutputConverterImpl implements ProtocolOutputConverter byte[] modifiedContent; // straight through case - boolean compressionSupported = _protocolSession.isCompressionSupported(); + boolean compressionSupported = _connection.isCompressionSupported(); if(msgCompressed && !compressionSupported && (modifiedContent = GZIPUtils.uncompressBufferToArray(message.getContent(0,bodySize))) != null) @@ -125,7 +115,7 @@ class ProtocolOutputConverterImpl implements ProtocolOutputConverter else if(!msgCompressed && compressionSupported && contentHeaderBody.getProperties().getEncoding()==null - && bodySize > _protocolSession.getMessageCompressionThreshold() + && bodySize > _connection.getMessageCompressionThreshold() && (modifiedContent = GZIPUtils.compressBufferToArray(message.getContent(0, bodySize))) != null) { BasicContentHeaderProperties modifiedProps = @@ -152,7 +142,7 @@ class ProtocolOutputConverterImpl implements ProtocolOutputConverter final int bodySize; bodySize = content.length; ContentHeaderBody modifiedHeaderBody = - new ContentHeaderBody(BASIC_CLASS_ID, 0, modifiedProps, bodySize); + new ContentHeaderBody(modifiedProps, bodySize); final MessageContentSource wrappedSource = new MessageContentSource() { @Override @@ -192,7 +182,7 @@ class ProtocolOutputConverterImpl implements ProtocolOutputConverter } else { - int maxBodySize = (int) getProtocolSession().getMaxFrameSize() - AMQFrame.getFrameOverhead(); + int maxBodySize = (int) _connection.getMaxFrameSize() - AMQFrame.getFrameOverhead(); int capacity = bodySize > maxBodySize ? maxBodySize : bodySize; @@ -326,11 +316,11 @@ class ProtocolOutputConverterImpl implements ProtocolOutputConverter public AMQBody createAMQBody() { - return _methodRegistry.createBasicDeliverBody(_consumerTag, - _deliveryTag, - _isRedelivered, - _exchangeName, - _routingKey); + return _connection.getMethodRegistry().createBasicDeliverBody(_consumerTag, + _deliveryTag, + _isRedelivered, + _exchangeName, + _routingKey); } public byte getFrameType() @@ -382,35 +372,25 @@ class ProtocolOutputConverterImpl implements ProtocolOutputConverter final boolean isRedelivered = Boolean.TRUE.equals(props.getProperty(InstanceProperties.Property.REDELIVERED)); BasicGetOkBody getOkBody = - _methodRegistry.createBasicGetOkBody(deliveryTag, - isRedelivered, - exchangeName, - routingKey, - queueSize); + _connection.getMethodRegistry().createBasicGetOkBody(deliveryTag, + isRedelivered, + exchangeName, + routingKey, + queueSize); return getOkBody; } - public byte getProtocolMinorVersion() - { - return _protocolSession.getProtocolMinorVersion(); - } - - public byte getProtocolMajorVersion() - { - return getProtocolSession().getProtocolMajorVersion(); - } - private AMQBody createEncodedReturnFrame(MessagePublishInfo messagePublishInfo, int replyCode, AMQShortString replyText) { BasicReturnBody basicReturnBody = - _methodRegistry.createBasicReturnBody(replyCode, - replyText, - messagePublishInfo.getExchange(), - messagePublishInfo.getRoutingKey()); + _connection.getMethodRegistry().createBasicReturnBody(replyCode, + replyText, + messagePublishInfo.getExchange(), + messagePublishInfo.getRoutingKey()); return basicReturnBody; @@ -427,14 +407,14 @@ class ProtocolOutputConverterImpl implements ProtocolOutputConverter public void writeFrame(AMQDataBlock block) { - getProtocolSession().writeFrame(block); + _connection.writeFrame(block); } public void confirmConsumerAutoClose(int channelId, AMQShortString consumerTag) { - BasicCancelOkBody basicCancelOkBody = _methodRegistry.createBasicCancelOkBody(consumerTag); + BasicCancelOkBody basicCancelOkBody = _connection.getMethodRegistry().createBasicCancelOkBody(consumerTag); writeFrame(basicCancelOkBody.generateFrame(channelId)); } diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/UnacknowledgedMessageMap.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/UnacknowledgedMessageMap.java index fcbbadd507..bd7b070cd2 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/UnacknowledgedMessageMap.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/UnacknowledgedMessageMap.java @@ -20,13 +20,12 @@ */ package org.apache.qpid.server.protocol.v0_8; -import org.apache.qpid.AMQException; -import org.apache.qpid.server.message.MessageInstance; -import org.apache.qpid.server.queue.QueueEntry; - import java.util.Collection; import java.util.Set; +import org.apache.qpid.AMQException; +import org.apache.qpid.server.message.MessageInstance; + public interface UnacknowledgedMessageMap { @@ -37,12 +36,12 @@ public interface UnacknowledgedMessageMap *@param message the message being iterated over @return true to stop iteration, false to continue * @throws AMQException */ - boolean callback(final long deliveryTag, MessageInstance message) throws AMQException; + boolean callback(final long deliveryTag, MessageInstance message); void visitComplete(); } - void visit(Visitor visitor) throws AMQException; + void visit(Visitor visitor); void add(long deliveryTag, MessageInstance message); diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/UnacknowledgedMessageMapImpl.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/UnacknowledgedMessageMapImpl.java index c33af48d8e..2d39daed1c 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/UnacknowledgedMessageMapImpl.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/UnacknowledgedMessageMapImpl.java @@ -27,7 +27,6 @@ import java.util.List; import java.util.Map; import java.util.Set; -import org.apache.qpid.AMQException; import org.apache.qpid.server.message.MessageInstance; public class UnacknowledgedMessageMapImpl implements UnacknowledgedMessageMap @@ -82,7 +81,7 @@ public class UnacknowledgedMessageMapImpl implements UnacknowledgedMessageMap } } - public void visit(Visitor visitor) throws AMQException + public void visit(Visitor visitor) { synchronized (_lock) { diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/UnexpectedMethodException.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/UnexpectedMethodException.java index cb14254494..432a725c86 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/UnexpectedMethodException.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/UnexpectedMethodException.java @@ -18,7 +18,7 @@ * under the License.
*
*/
-package org.apache.qpid.server.protocol.v0_8.handler;
+package org.apache.qpid.server.protocol.v0_8;
import org.apache.qpid.AMQException;
diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/AccessRequestHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/AccessRequestHandler.java deleted file mode 100644 index ae07d60c4e..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/AccessRequestHandler.java +++ /dev/null @@ -1,85 +0,0 @@ -/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
- */
-package org.apache.qpid.server.protocol.v0_8.handler;
-
-
-import org.apache.qpid.AMQException;
-import org.apache.qpid.framing.AccessRequestBody;
-import org.apache.qpid.framing.AccessRequestOkBody;
-import org.apache.qpid.framing.MethodRegistry;
-import org.apache.qpid.framing.amqp_0_9.MethodRegistry_0_9;
-import org.apache.qpid.framing.amqp_8_0.MethodRegistry_8_0;
-import org.apache.qpid.protocol.AMQConstant;
-import org.apache.qpid.server.protocol.v0_8.AMQChannel;
-import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession;
-import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager;
-import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener;
-
-/**
- * @author Apache Software Foundation
- *
- *
- */
-public class AccessRequestHandler implements StateAwareMethodListener<AccessRequestBody>
-{
- private static final AccessRequestHandler _instance = new AccessRequestHandler();
-
-
- public static AccessRequestHandler getInstance()
- {
- return _instance;
- }
-
- private AccessRequestHandler()
- {
- }
-
- public void methodReceived(AMQStateManager stateManager, AccessRequestBody body, int channelId) throws AMQException
- {
- AMQProtocolSession session = stateManager.getProtocolSession();
- final AMQChannel channel = session.getChannel(channelId);
- if (channel == null)
- {
- throw body.getChannelNotFoundException(channelId);
- }
-
- MethodRegistry methodRegistry = session.getMethodRegistry();
-
- // We don't implement access control class, but to keep clients happy that expect it
- // always use the "0" ticket.
- AccessRequestOkBody response;
- if(methodRegistry instanceof MethodRegistry_0_9)
- {
- response = ((MethodRegistry_0_9)methodRegistry).createAccessRequestOkBody(0);
- }
- else if(methodRegistry instanceof MethodRegistry_8_0)
- {
- response = ((MethodRegistry_8_0)methodRegistry).createAccessRequestOkBody(0);
- }
- else
- {
- throw new AMQException(AMQConstant.COMMAND_INVALID, "AccessRequest not present in AMQP versions other than 0-8, 0-9");
- }
-
- channel.sync();
- session.writeFrame(response.generateFrame(channelId));
- }
-}
diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicAckMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicAckMethodHandler.java deleted file mode 100644 index f623d27e87..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicAckMethodHandler.java +++ /dev/null @@ -1,67 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.BasicAckBody; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class BasicAckMethodHandler implements StateAwareMethodListener<BasicAckBody> -{ - private static final Logger _log = Logger.getLogger(BasicAckMethodHandler.class); - - private static final BasicAckMethodHandler _instance = new BasicAckMethodHandler(); - - public static BasicAckMethodHandler getInstance() - { - return _instance; - } - - private BasicAckMethodHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, BasicAckBody body, int channelId) throws AMQException - { - AMQProtocolSession protocolSession = stateManager.getProtocolSession(); - - - if (_log.isDebugEnabled()) - { - _log.debug("Ack(Tag:" + body.getDeliveryTag() + ":Mult:" + body.getMultiple() + ") received on channel " + channelId); - } - - final AMQChannel channel = protocolSession.getChannel(channelId); - - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - - // this method throws an AMQException if the delivery tag is not known - channel.acknowledgeMessage(body.getDeliveryTag(), body.getMultiple()); - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicCancelMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicCancelMethodHandler.java deleted file mode 100644 index 5a6a7bdc18..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicCancelMethodHandler.java +++ /dev/null @@ -1,76 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.BasicCancelBody; -import org.apache.qpid.framing.BasicCancelOkBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class BasicCancelMethodHandler implements StateAwareMethodListener<BasicCancelBody> -{ - private static final Logger _log = Logger.getLogger(BasicCancelMethodHandler.class); - - private static final BasicCancelMethodHandler _instance = new BasicCancelMethodHandler(); - - public static BasicCancelMethodHandler getInstance() - { - return _instance; - } - - private BasicCancelMethodHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, BasicCancelBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - - final AMQChannel channel = session.getChannel(channelId); - - - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - - if (_log.isDebugEnabled()) - { - _log.debug("BasicCancel: for:" + body.getConsumerTag() + - " nowait:" + body.getNowait()); - } - - channel.unsubscribeConsumer(body.getConsumerTag()); - if (!body.getNowait()) - { - MethodRegistry methodRegistry = session.getMethodRegistry(); - BasicCancelOkBody cancelOkBody = methodRegistry.createBasicCancelOkBody(body.getConsumerTag()); - channel.sync(); - session.writeFrame(cancelOkBody.generateFrame(channelId)); - } - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicConsumeMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicConsumeMethodHandler.java deleted file mode 100644 index c1e3d850ef..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicConsumeMethodHandler.java +++ /dev/null @@ -1,220 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import java.security.AccessControlException; -import java.util.Collection; -import java.util.HashSet; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.BasicConsumeBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.filter.AMQInvalidArgumentException; -import org.apache.qpid.server.message.MessageSource; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.queue.AMQQueue; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - -public class BasicConsumeMethodHandler implements StateAwareMethodListener<BasicConsumeBody> -{ - private static final Logger _logger = Logger.getLogger(BasicConsumeMethodHandler.class); - - private static final BasicConsumeMethodHandler _instance = new BasicConsumeMethodHandler(); - - public static BasicConsumeMethodHandler getInstance() - { - return _instance; - } - - private BasicConsumeMethodHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, BasicConsumeBody body, int channelId) throws AMQException - { - AMQProtocolSession protocolConnection = stateManager.getProtocolSession(); - - AMQChannel channel = protocolConnection.getChannel(channelId); - VirtualHostImpl<?,?,?> vHost = protocolConnection.getVirtualHost(); - - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - else - { - channel.sync(); - String queueName = body.getQueue() == null ? null : body.getQueue().asString(); - if (_logger.isDebugEnabled()) - { - _logger.debug("BasicConsume: from '" + queueName + - "' for:" + body.getConsumerTag() + - " nowait:" + body.getNowait() + - " args:" + body.getArguments()); - } - - MessageSource queue = queueName == null ? channel.getDefaultQueue() : vHost.getQueue(queueName); - final Collection<MessageSource> sources = new HashSet<>(); - if(queue != null) - { - sources.add(queue); - } - else if(vHost.getContextValue(Boolean.class, "qpid.enableMultiQueueConsumers") - && body.getArguments() != null - && body.getArguments().get("x-multiqueue") instanceof Collection) - { - for(Object object : (Collection<Object>)body.getArguments().get("x-multiqueue")) - { - String sourceName = String.valueOf(object); - sourceName = sourceName.trim(); - if(sourceName.length() != 0) - { - MessageSource source = vHost.getMessageSource(sourceName); - if(source == null) - { - sources.clear(); - break; - } - else - { - sources.add(source); - } - } - } - queueName = body.getArguments().get("x-multiqueue").toString(); - } - - if (sources.isEmpty()) - { - if (_logger.isDebugEnabled()) - { - _logger.debug("No queue for '" + queueName + "'"); - } - if (queueName != null) - { - String msg = "No such queue, '" + queueName + "'"; - throw body.getChannelException(AMQConstant.NOT_FOUND, msg); - } - else - { - String msg = "No queue name provided, no default queue defined."; - throw body.getConnectionException(AMQConstant.NOT_ALLOWED, msg); - } - } - else - { - final AMQShortString consumerTagName; - - if (body.getConsumerTag() != null) - { - consumerTagName = body.getConsumerTag().intern(false); - } - else - { - consumerTagName = null; - } - - try - { - if(consumerTagName == null || channel.getSubscription(consumerTagName) == null) - { - - AMQShortString consumerTag = channel.consumeFromSource(consumerTagName, - sources, - !body.getNoAck(), - body.getArguments(), - body.getExclusive(), - body.getNoLocal()); - if (!body.getNowait()) - { - MethodRegistry methodRegistry = protocolConnection.getMethodRegistry(); - AMQMethodBody responseBody = methodRegistry.createBasicConsumeOkBody(consumerTag); - protocolConnection.writeFrame(responseBody.generateFrame(channelId)); - - } - } - else - { - AMQShortString msg = AMQShortString.validValueOf("Non-unique consumer tag, '" + body.getConsumerTag() + "'"); - - MethodRegistry methodRegistry = protocolConnection.getMethodRegistry(); - AMQMethodBody responseBody = methodRegistry.createConnectionCloseBody(AMQConstant.NOT_ALLOWED.getCode(), // replyCode - msg, // replytext - body.getClazz(), - body.getMethod()); - protocolConnection.writeFrame(responseBody.generateFrame(0)); - } - - } - catch (AMQInvalidArgumentException ise) - { - _logger.debug("Closing connection due to invalid selector"); - - MethodRegistry methodRegistry = protocolConnection.getMethodRegistry(); - AMQMethodBody responseBody = methodRegistry.createChannelCloseBody(AMQConstant.ARGUMENT_INVALID.getCode(), - AMQShortString.validValueOf(ise.getMessage()), - body.getClazz(), - body.getMethod()); - protocolConnection.writeFrame(responseBody.generateFrame(channelId)); - - - } - catch (AMQQueue.ExistingExclusiveConsumer e) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, - "Cannot subscribe to queue " - + queue.getName() - + " as it already has an existing exclusive consumer"); - } - catch (AMQQueue.ExistingConsumerPreventsExclusive e) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, - "Cannot subscribe to queue " - + queue.getName() - + " exclusively as it already has a consumer"); - } - catch (AccessControlException e) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, - "Cannot subscribe to queue " - + queue.getName() - + " permission denied"); - } - catch (MessageSource.ConsumerAccessRefused consumerAccessRefused) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, - "Cannot subscribe to queue " - + queue.getName() - + " as it already has an incompatible exclusivity policy"); - } - - } - } - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicGetMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicGetMethodHandler.java deleted file mode 100644 index c3bdedf44d..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicGetMethodHandler.java +++ /dev/null @@ -1,224 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - * - */ - -package org.apache.qpid.server.protocol.v0_8.handler; - -import java.security.AccessControlException; -import java.util.EnumSet; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.BasicGetBody; -import org.apache.qpid.framing.BasicGetEmptyBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.consumer.ConsumerImpl; -import org.apache.qpid.server.flow.FlowCreditManager; -import org.apache.qpid.server.flow.MessageOnlyCreditManager; -import org.apache.qpid.server.message.InstanceProperties; -import org.apache.qpid.server.message.MessageInstance; -import org.apache.qpid.server.message.MessageSource; -import org.apache.qpid.server.message.ServerMessage; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQMessage; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.ClientDeliveryMethod; -import org.apache.qpid.server.protocol.v0_8.ConsumerTarget_0_8; -import org.apache.qpid.server.protocol.v0_8.RecordDeliveryMethod; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.queue.AMQQueue; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - -public class BasicGetMethodHandler implements StateAwareMethodListener<BasicGetBody> -{ - private static final Logger _log = Logger.getLogger(BasicGetMethodHandler.class); - - private static final BasicGetMethodHandler _instance = new BasicGetMethodHandler(); - - public static BasicGetMethodHandler getInstance() - { - return _instance; - } - - private BasicGetMethodHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, BasicGetBody body, int channelId) throws AMQException - { - AMQProtocolSession protocolConnection = stateManager.getProtocolSession(); - - - VirtualHostImpl vHost = protocolConnection.getVirtualHost(); - - AMQChannel channel = protocolConnection.getChannel(channelId); - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - else - { - channel.sync(); - AMQQueue queue = body.getQueue() == null ? channel.getDefaultQueue() : vHost.getQueue(body.getQueue().toString()); - if (queue == null) - { - _log.info("No queue for '" + body.getQueue() + "'"); - if(body.getQueue()!=null) - { - throw body.getConnectionException(AMQConstant.NOT_FOUND, - "No such queue, '" + body.getQueue()+ "'"); - } - else - { - throw body.getConnectionException(AMQConstant.NOT_ALLOWED, - "No queue name provided, no default queue defined."); - } - } - else - { - - try - { - if (!performGet(queue,protocolConnection, channel, !body.getNoAck())) - { - MethodRegistry methodRegistry = protocolConnection.getMethodRegistry(); - // TODO - set clusterId - BasicGetEmptyBody responseBody = methodRegistry.createBasicGetEmptyBody(null); - - - protocolConnection.writeFrame(responseBody.generateFrame(channelId)); - } - } - catch (AccessControlException e) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, - e.getMessage()); - } - catch (MessageSource.ExistingExclusiveConsumer e) - { - throw body.getConnectionException(AMQConstant.NOT_ALLOWED, - "Queue has an exclusive consumer"); - } - catch (MessageSource.ExistingConsumerPreventsExclusive e) - { - throw body.getConnectionException(AMQConstant.INTERNAL_ERROR, - "The GET request has been evaluated as an exclusive consumer, " + - "this is likely due to a programming error in the Qpid broker"); - } - catch (MessageSource.ConsumerAccessRefused consumerAccessRefused) - { - throw body.getConnectionException(AMQConstant.NOT_ALLOWED, - "Queue has an incompatible exclusivit policy"); - } - } - } - } - - public static boolean performGet(final AMQQueue queue, - final AMQProtocolSession session, - final AMQChannel channel, - final boolean acks) - throws AMQException, MessageSource.ExistingConsumerPreventsExclusive, - MessageSource.ExistingExclusiveConsumer, MessageSource.ConsumerAccessRefused - { - - final FlowCreditManager singleMessageCredit = new MessageOnlyCreditManager(1L); - - final GetDeliveryMethod getDeliveryMethod = - new GetDeliveryMethod(singleMessageCredit, session, channel, queue); - final RecordDeliveryMethod getRecordMethod = new RecordDeliveryMethod() - { - - public void recordMessageDelivery(final ConsumerImpl sub, final MessageInstance entry, final long deliveryTag) - { - channel.addUnacknowledgedMessage(entry, deliveryTag, null); - } - }; - - ConsumerTarget_0_8 target; - EnumSet<ConsumerImpl.Option> options = EnumSet.of(ConsumerImpl.Option.TRANSIENT, ConsumerImpl.Option.ACQUIRES, - ConsumerImpl.Option.SEES_REQUEUES); - if(acks) - { - - target = ConsumerTarget_0_8.createAckTarget(channel, - AMQShortString.EMPTY_STRING, null, - singleMessageCredit, getDeliveryMethod, getRecordMethod); - } - else - { - target = ConsumerTarget_0_8.createGetNoAckTarget(channel, - AMQShortString.EMPTY_STRING, null, - singleMessageCredit, getDeliveryMethod, getRecordMethod); - } - - ConsumerImpl sub = queue.addConsumer(target, null, AMQMessage.class, "", options); - sub.flush(); - sub.close(); - return(getDeliveryMethod.hasDeliveredMessage()); - - - } - - - private static class GetDeliveryMethod implements ClientDeliveryMethod - { - - private final FlowCreditManager _singleMessageCredit; - private final AMQProtocolSession _session; - private final AMQChannel _channel; - private final AMQQueue _queue; - private boolean _deliveredMessage; - - public GetDeliveryMethod(final FlowCreditManager singleMessageCredit, - final AMQProtocolSession session, - final AMQChannel channel, final AMQQueue queue) - { - _singleMessageCredit = singleMessageCredit; - _session = session; - _channel = channel; - _queue = queue; - } - - @Override - public long deliverToClient(final ConsumerImpl sub, final ServerMessage message, - final InstanceProperties props, final long deliveryTag) - { - _singleMessageCredit.useCreditForMessage(message.getSize()); - long size =_session.getProtocolOutputConverter().writeGetOk(message, - props, - _channel.getChannelId(), - deliveryTag, - _queue.getQueueDepthMessages()); - - _deliveredMessage = true; - return size; - } - - public boolean hasDeliveredMessage() - { - return _deliveredMessage; - } - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicPublishMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicPublishMethodHandler.java deleted file mode 100644 index 0d09c31ec8..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicPublishMethodHandler.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.BasicPublishBody; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.message.MessageDestination; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - -import java.security.AccessControlException; - -public class BasicPublishMethodHandler implements StateAwareMethodListener<BasicPublishBody> -{ - private static final Logger _logger = Logger.getLogger(BasicPublishMethodHandler.class); - - private static final BasicPublishMethodHandler _instance = new BasicPublishMethodHandler(); - - - public static BasicPublishMethodHandler getInstance() - { - return _instance; - } - - private BasicPublishMethodHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, BasicPublishBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - if (_logger.isDebugEnabled()) - { - _logger.debug("Publish received on channel " + channelId); - } - - AMQShortString exchangeName = body.getExchange(); - VirtualHostImpl vHost = session.getVirtualHost(); - - // TODO: check the delivery tag field details - is it unique across the broker or per subscriber? - - MessageDestination destination; - - if (exchangeName == null || AMQShortString.EMPTY_STRING.equals(exchangeName)) - { - destination = vHost.getDefaultDestination(); - } - else - { - destination = vHost.getMessageDestination(exchangeName.toString()); - } - - // if the exchange does not exist we raise a channel exception - if (destination == null) - { - throw body.getChannelException(AMQConstant.NOT_FOUND, "Unknown exchange name"); - } - else - { - // The partially populated BasicDeliver frame plus the received route body - // is stored in the channel. Once the final body frame has been received - // it is routed to the exchange. - AMQChannel channel = session.getChannel(channelId); - - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - - MessagePublishInfo info = session.getMethodRegistry().getProtocolVersionMethodConverter().convertToInfo(body); - info.setExchange(exchangeName); - try - { - channel.setPublishFrame(info, destination); - } - catch (AccessControlException e) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, e.getMessage()); - } - } - } - -} - - - diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicQosHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicQosHandler.java deleted file mode 100644 index e4a6636a74..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicQosHandler.java +++ /dev/null @@ -1,58 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.BasicQosBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class BasicQosHandler implements StateAwareMethodListener<BasicQosBody> -{ - private static final BasicQosHandler _instance = new BasicQosHandler(); - - public static BasicQosHandler getInstance() - { - return _instance; - } - - public void methodReceived(AMQStateManager stateManager, BasicQosBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - AMQChannel channel = session.getChannel(channelId); - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - channel.sync(); - channel.setCredit(body.getPrefetchSize(), body.getPrefetchCount()); - - - MethodRegistry methodRegistry = session.getMethodRegistry(); - AMQMethodBody responseBody = methodRegistry.createBasicQosOkBody(); - session.writeFrame(responseBody.generateFrame(channelId)); - - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicRecoverMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicRecoverMethodHandler.java deleted file mode 100644 index 606bcf1693..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicRecoverMethodHandler.java +++ /dev/null @@ -1,73 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.BasicRecoverBody; -import org.apache.qpid.framing.ProtocolVersion; -import org.apache.qpid.framing.amqp_8_0.MethodRegistry_8_0; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class BasicRecoverMethodHandler implements StateAwareMethodListener<BasicRecoverBody> -{ - private static final Logger _logger = Logger.getLogger(BasicRecoverMethodHandler.class); - - private static final BasicRecoverMethodHandler _instance = new BasicRecoverMethodHandler(); - - public static BasicRecoverMethodHandler getInstance() - { - return _instance; - } - - public void methodReceived(AMQStateManager stateManager, BasicRecoverBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - - _logger.debug("Recover received on protocol session " + session + " and channel " + channelId); - AMQChannel channel = session.getChannel(channelId); - - - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - - channel.resend(); - - // Qpid 0-8 hacks a synchronous -ok onto recover. - // In Qpid 0-9 we create a separate sync-recover, sync-recover-ok pair to be "more" compliant - if(session.getProtocolVersion().equals(ProtocolVersion.v8_0)) - { - MethodRegistry_8_0 methodRegistry = (MethodRegistry_8_0) session.getMethodRegistry(); - AMQMethodBody recoverOk = methodRegistry.createBasicRecoverOkBody(); - channel.sync(); - session.writeFrame(recoverOk.generateFrame(channelId)); - - } - - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicRecoverSyncMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicRecoverSyncMethodHandler.java deleted file mode 100644 index ef26e60a62..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicRecoverSyncMethodHandler.java +++ /dev/null @@ -1,81 +0,0 @@ -/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
- */
-package org.apache.qpid.server.protocol.v0_8.handler;
-
-
-import org.apache.log4j.Logger;
-
-import org.apache.qpid.AMQException;
-import org.apache.qpid.framing.AMQMethodBody;
-import org.apache.qpid.framing.BasicRecoverSyncBody;
-import org.apache.qpid.framing.ProtocolVersion;
-import org.apache.qpid.framing.amqp_0_9.MethodRegistry_0_9;
-import org.apache.qpid.framing.amqp_0_91.MethodRegistry_0_91;
-import org.apache.qpid.server.protocol.v0_8.AMQChannel;
-import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession;
-import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager;
-import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener;
-
-public class BasicRecoverSyncMethodHandler implements StateAwareMethodListener<BasicRecoverSyncBody>
-{
- private static final Logger _logger = Logger.getLogger(BasicRecoverSyncMethodHandler.class);
-
- private static final BasicRecoverSyncMethodHandler _instance = new BasicRecoverSyncMethodHandler();
-
- public static BasicRecoverSyncMethodHandler getInstance()
- {
- return _instance;
- }
-
- public void methodReceived(AMQStateManager stateManager, BasicRecoverSyncBody body, int channelId) throws AMQException
- {
- AMQProtocolSession session = stateManager.getProtocolSession();
-
- _logger.debug("Recover received on protocol session " + session + " and channel " + channelId);
- AMQChannel channel = session.getChannel(channelId);
-
-
- if (channel == null)
- {
- throw body.getChannelNotFoundException(channelId);
- }
- channel.sync();
- channel.resend();
-
- // Qpid 0-8 hacks a synchronous -ok onto recover.
- // In Qpid 0-9 we create a separate sync-recover, sync-recover-ok pair to be "more" compliant
- if(session.getProtocolVersion().equals(ProtocolVersion.v0_9))
- {
- MethodRegistry_0_9 methodRegistry = (MethodRegistry_0_9) session.getMethodRegistry();
- AMQMethodBody recoverOk = methodRegistry.createBasicRecoverSyncOkBody();
- session.writeFrame(recoverOk.generateFrame(channelId));
-
- }
- else if(session.getProtocolVersion().equals(ProtocolVersion.v0_91))
- {
- MethodRegistry_0_91 methodRegistry = (MethodRegistry_0_91) session.getMethodRegistry();
- AMQMethodBody recoverOk = methodRegistry.createBasicRecoverSyncOkBody();
- session.writeFrame(recoverOk.generateFrame(channelId));
-
- }
-
- }
-}
diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicRejectMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicRejectMethodHandler.java deleted file mode 100644 index fdbd44b06d..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/BasicRejectMethodHandler.java +++ /dev/null @@ -1,132 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.BasicRejectBody; -import org.apache.qpid.server.message.MessageInstance; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.queue.QueueEntry; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class BasicRejectMethodHandler implements StateAwareMethodListener<BasicRejectBody> -{ - private static final Logger _logger = Logger.getLogger(BasicRejectMethodHandler.class); - - private static BasicRejectMethodHandler _instance = new BasicRejectMethodHandler(); - - public static BasicRejectMethodHandler getInstance() - { - return _instance; - } - - private BasicRejectMethodHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, BasicRejectBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - - AMQChannel channel = session.getChannel(channelId); - - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - - if (_logger.isDebugEnabled()) - { - _logger.debug("Rejecting:" + body.getDeliveryTag() + - ": Requeue:" + body.getRequeue() + - " on channel:" + channel.debugIdentity()); - } - - long deliveryTag = body.getDeliveryTag(); - - MessageInstance message = channel.getUnacknowledgedMessageMap().get(deliveryTag); - - if (message == null) - { - _logger.warn("Dropping reject request as message is null for tag:" + deliveryTag); - } - else - { - - if (message.getMessage() == null) - { - _logger.warn("Message has already been purged, unable to Reject."); - return; - } - - - if (_logger.isDebugEnabled()) - { - _logger.debug("Rejecting: DT:" + deliveryTag + "-" + message.getMessage() + - ": Requeue:" + body.getRequeue() + - " on channel:" + channel.debugIdentity()); - } - - if (body.getRequeue()) - { - //this requeue represents a message rejected from the pre-dispatch queue - //therefore we need to amend the delivery counter. - message.decrementDeliveryCount(); - - channel.requeue(deliveryTag); - } - else - { - // Since the Java client abuses the reject flag for requeing after rollback, we won't set reject here - // as it would prevent redelivery - // message.reject(); - - final boolean maxDeliveryCountEnabled = channel.isMaxDeliveryCountEnabled(deliveryTag); - _logger.debug("maxDeliveryCountEnabled: " + maxDeliveryCountEnabled + " deliveryTag " + deliveryTag); - if (maxDeliveryCountEnabled) - { - final boolean deliveredTooManyTimes = channel.isDeliveredTooManyTimes(deliveryTag); - _logger.debug("deliveredTooManyTimes: " + deliveredTooManyTimes + " deliveryTag " + deliveryTag); - if (deliveredTooManyTimes) - { - channel.deadLetter(body.getDeliveryTag()); - } - else - { - //this requeue represents a message rejected because of a recover/rollback that we - //are not ready to DLQ. We rely on the reject command to resend from the unacked map - //and therefore need to increment the delivery counter so we cancel out the effect - //of the AMQChannel#resend() decrement. - message.incrementDeliveryCount(); - } - } - else - { - channel.requeue(deliveryTag); - } - } - } - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ChannelCloseHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ChannelCloseHandler.java deleted file mode 100644 index e96d098618..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ChannelCloseHandler.java +++ /dev/null @@ -1,76 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.ChannelCloseBody; -import org.apache.qpid.framing.ChannelCloseOkBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class ChannelCloseHandler implements StateAwareMethodListener<ChannelCloseBody> -{ - private static final Logger _logger = Logger.getLogger(ChannelCloseHandler.class); - - private static ChannelCloseHandler _instance = new ChannelCloseHandler(); - - public static ChannelCloseHandler getInstance() - { - return _instance; - } - - private ChannelCloseHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, ChannelCloseBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - - if (_logger.isInfoEnabled()) - { - _logger.info("Received channel close for id " + channelId + " citing class " + body.getClassId() + - " and method " + body.getMethodId()); - } - - - AMQChannel channel = session.getChannel(channelId); - - if (channel == null) - { - throw body.getConnectionException(AMQConstant.CHANNEL_ERROR, "Trying to close unknown channel"); - } - channel.sync(); - session.closeChannel(channelId); - // Client requested closure so we don't wait for ok we send it - stateManager.getProtocolSession().closeChannelOk(channelId); - - MethodRegistry methodRegistry = session.getMethodRegistry(); - ChannelCloseOkBody responseBody = methodRegistry.createChannelCloseOkBody(); - session.writeFrame(responseBody.generateFrame(channelId)); - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ChannelCloseOkHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ChannelCloseOkHandler.java deleted file mode 100644 index 2a220ff78d..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ChannelCloseOkHandler.java +++ /dev/null @@ -1,53 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.ChannelCloseOkBody; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class ChannelCloseOkHandler implements StateAwareMethodListener<ChannelCloseOkBody> -{ - private static final Logger _logger = Logger.getLogger(ChannelCloseOkHandler.class); - - private static ChannelCloseOkHandler _instance = new ChannelCloseOkHandler(); - - public static ChannelCloseOkHandler getInstance() - { - return _instance; - } - - private ChannelCloseOkHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, ChannelCloseOkBody body, int channelId) throws AMQException - { - - _logger.info("Received channel-close-ok for channel-id " + channelId); - - // Let the Protocol Session know the channel is now closed. - stateManager.getProtocolSession().closeChannelOk(channelId); - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ChannelFlowHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ChannelFlowHandler.java deleted file mode 100644 index cc1677c93e..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ChannelFlowHandler.java +++ /dev/null @@ -1,68 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.ChannelFlowBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class ChannelFlowHandler implements StateAwareMethodListener<ChannelFlowBody> -{ - private static final Logger _logger = Logger.getLogger(ChannelFlowHandler.class); - - private static ChannelFlowHandler _instance = new ChannelFlowHandler(); - - public static ChannelFlowHandler getInstance() - { - return _instance; - } - - private ChannelFlowHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, ChannelFlowBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - - - AMQChannel channel = session.getChannel(channelId); - - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - channel.sync(); - channel.setSuspended(!body.getActive()); - _logger.debug("Channel.Flow for channel " + channelId + ", active=" + body.getActive()); - - MethodRegistry methodRegistry = session.getMethodRegistry(); - AMQMethodBody responseBody = methodRegistry.createChannelFlowOkBody(body.getActive()); - session.writeFrame(responseBody.generateFrame(channelId)); - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ChannelOpenHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ChannelOpenHandler.java deleted file mode 100644 index 63c6857216..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ChannelOpenHandler.java +++ /dev/null @@ -1,143 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.ChannelOpenBody; -import org.apache.qpid.framing.ChannelOpenOkBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.ProtocolVersion; -import org.apache.qpid.framing.amqp_0_9.MethodRegistry_0_9; -import org.apache.qpid.framing.amqp_0_91.MethodRegistry_0_91; -import org.apache.qpid.framing.amqp_8_0.MethodRegistry_8_0; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.util.ConnectionScopedRuntimeException; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - -import java.io.ByteArrayOutputStream; -import java.io.DataOutputStream; -import java.io.IOException; -import java.util.UUID; - -public class ChannelOpenHandler implements StateAwareMethodListener<ChannelOpenBody> -{ - private static final Logger _logger = Logger.getLogger(ChannelOpenHandler.class); - - private static ChannelOpenHandler _instance = new ChannelOpenHandler(); - - public static ChannelOpenHandler getInstance() - { - return _instance; - } - - private ChannelOpenHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, ChannelOpenBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - VirtualHostImpl virtualHost = session.getVirtualHost(); - - // Protect the broker against out of order frame request. - if (virtualHost == null) - { - throw new AMQException(AMQConstant.COMMAND_INVALID, "Virtualhost has not yet been set. ConnectionOpen has not been called.", null); - } - _logger.info("Connecting to: " + virtualHost.getName()); - - final AMQChannel channel = new AMQChannel(session,channelId, virtualHost.getMessageStore()); - - session.addChannel(channel); - - ChannelOpenOkBody response; - - ProtocolVersion pv = session.getProtocolVersion(); - - if(pv.equals(ProtocolVersion.v8_0)) - { - MethodRegistry_8_0 methodRegistry = (MethodRegistry_8_0) MethodRegistry.getMethodRegistry(ProtocolVersion.v8_0); - response = methodRegistry.createChannelOpenOkBody(); - - } - else if(pv.equals(ProtocolVersion.v0_9)) - { - MethodRegistry_0_9 methodRegistry = (MethodRegistry_0_9) MethodRegistry.getMethodRegistry(ProtocolVersion.v0_9); - UUID uuid = UUID.randomUUID(); - ByteArrayOutputStream output = new ByteArrayOutputStream(); - DataOutputStream dataOut = new DataOutputStream(output); - try - { - dataOut.writeLong(uuid.getMostSignificantBits()); - dataOut.writeLong(uuid.getLeastSignificantBits()); - dataOut.flush(); - dataOut.close(); - } - catch (IOException e) - { - // This *really* shouldn't happen as we're not doing any I/O - throw new ConnectionScopedRuntimeException("I/O exception when writing to byte array", e); - } - - // should really associate this channelId to the session - byte[] channelName = output.toByteArray(); - - response = methodRegistry.createChannelOpenOkBody(channelName); - } - else if(pv.equals(ProtocolVersion.v0_91)) - { - MethodRegistry_0_91 methodRegistry = (MethodRegistry_0_91) MethodRegistry.getMethodRegistry(ProtocolVersion.v0_91); - UUID uuid = UUID.randomUUID(); - ByteArrayOutputStream output = new ByteArrayOutputStream(); - DataOutputStream dataOut = new DataOutputStream(output); - try - { - dataOut.writeLong(uuid.getMostSignificantBits()); - dataOut.writeLong(uuid.getLeastSignificantBits()); - dataOut.flush(); - dataOut.close(); - } - catch (IOException e) - { - // This *really* shouldn't happen as we're not doing any I/O - throw new ConnectionScopedRuntimeException("I/O exception when writing to byte array", e); - } - - // should really associate this channelId to the session - byte[] channelName = output.toByteArray(); - - response = methodRegistry.createChannelOpenOkBody(channelName); - } - else - { - throw new AMQException(AMQConstant.INTERNAL_ERROR, "Got channel open for protocol version not catered for: " + pv, null); - } - - - session.writeFrame(response.generateFrame(channelId)); - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionCloseMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionCloseMethodHandler.java deleted file mode 100644 index 60f9c1d495..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionCloseMethodHandler.java +++ /dev/null @@ -1,72 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.ConnectionCloseBody; -import org.apache.qpid.framing.ConnectionCloseOkBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class ConnectionCloseMethodHandler implements StateAwareMethodListener<ConnectionCloseBody> -{ - private static final Logger _logger = Logger.getLogger(ConnectionCloseMethodHandler.class); - - private static ConnectionCloseMethodHandler _instance = new ConnectionCloseMethodHandler(); - - public static ConnectionCloseMethodHandler getInstance() - { - return _instance; - } - - private ConnectionCloseMethodHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, ConnectionCloseBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - if (_logger.isInfoEnabled()) - { - _logger.info("ConnectionClose received with reply code/reply text " + body.getReplyCode() + "/" + - body.getReplyText() + " for " + session); - } - try - { - session.closeSession(); - } - catch (Exception e) - { - _logger.error("Error closing protocol session: " + e, e); - } - - MethodRegistry methodRegistry = session.getMethodRegistry(); - ConnectionCloseOkBody responseBody = methodRegistry.createConnectionCloseOkBody(); - session.writeFrame(responseBody.generateFrame(channelId)); - - session.closeProtocolSession(); - - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionCloseOkMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionCloseOkMethodHandler.java deleted file mode 100644 index fe46b6c0cd..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionCloseOkMethodHandler.java +++ /dev/null @@ -1,63 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.ConnectionCloseOkBody; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQState; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class ConnectionCloseOkMethodHandler implements StateAwareMethodListener<ConnectionCloseOkBody> -{ - private static final Logger _logger = Logger.getLogger(ConnectionCloseOkMethodHandler.class); - - private static ConnectionCloseOkMethodHandler _instance = new ConnectionCloseOkMethodHandler(); - - public static ConnectionCloseOkMethodHandler getInstance() - { - return _instance; - } - - private ConnectionCloseOkMethodHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, ConnectionCloseOkBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - //todo should this not do more than just log the method? - _logger.info("Received Connection-close-ok"); - - try - { - stateManager.changeState(AMQState.CONNECTION_CLOSED); - session.closeSession(); - } - catch (Exception e) - { - _logger.error("Error closing protocol session: " + e, e); - } - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionOpenMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionOpenMethodHandler.java deleted file mode 100644 index 632f751756..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionOpenMethodHandler.java +++ /dev/null @@ -1,114 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import java.security.AccessControlException; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.ConnectionOpenBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.model.State; -import org.apache.qpid.server.model.port.AmqpPort; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQState; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - -public class ConnectionOpenMethodHandler implements StateAwareMethodListener<ConnectionOpenBody> -{ - private static final Logger _logger = Logger.getLogger(ConnectionOpenMethodHandler.class); - - private static ConnectionOpenMethodHandler _instance = new ConnectionOpenMethodHandler(); - - public static ConnectionOpenMethodHandler getInstance() - { - return _instance; - } - - private ConnectionOpenMethodHandler() - { - } - - private static AMQShortString generateClientID() - { - return new AMQShortString(Long.toString(System.currentTimeMillis())); - } - - public void methodReceived(AMQStateManager stateManager, ConnectionOpenBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - - //ignore leading '/' - String virtualHostName; - if ((body.getVirtualHost() != null) && body.getVirtualHost().charAt(0) == '/') - { - virtualHostName = new StringBuilder(body.getVirtualHost().subSequence(1, body.getVirtualHost().length())).toString(); - } - else - { - virtualHostName = body.getVirtualHost() == null ? null : String.valueOf(body.getVirtualHost()); - } - - VirtualHostImpl virtualHost = ((AmqpPort)stateManager.getProtocolSession().getPort()).getVirtualHost(virtualHostName); - - if (virtualHost == null) - { - throw body.getConnectionException(AMQConstant.NOT_FOUND, "Unknown virtual host: '" + virtualHostName + "'"); - } - else - { - // Check virtualhost access - if (virtualHost.getState() != State.ACTIVE) - { - throw body.getConnectionException(AMQConstant.CONNECTION_FORCED, "Virtual host '" + virtualHost.getName() + "' is not active"); - } - - session.setVirtualHost(virtualHost); - try - { - virtualHost.getSecurityManager().authoriseCreateConnection(session); - } - catch (AccessControlException e) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, e.getMessage()); - } - - // See Spec (0.8.2). Section 3.1.2 Virtual Hosts - if (session.getContextKey() == null) - { - session.setContextKey(generateClientID()); - } - - MethodRegistry methodRegistry = session.getMethodRegistry(); - AMQMethodBody responseBody = methodRegistry.createConnectionOpenOkBody(body.getVirtualHost()); - - stateManager.changeState(AMQState.CONNECTION_OPEN); - - session.writeFrame(responseBody.generateFrame(channelId)); - } - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionSecureOkMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionSecureOkMethodHandler.java deleted file mode 100644 index 8a1160314b..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionSecureOkMethodHandler.java +++ /dev/null @@ -1,138 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - - -import javax.security.sasl.SaslException; -import javax.security.sasl.SaslServer; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.ConnectionCloseBody; -import org.apache.qpid.framing.ConnectionSecureBody; -import org.apache.qpid.framing.ConnectionSecureOkBody; -import org.apache.qpid.framing.ConnectionTuneBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.model.Broker; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQState; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.security.SubjectCreator; -import org.apache.qpid.server.security.auth.SubjectAuthenticationResult; - -public class ConnectionSecureOkMethodHandler implements StateAwareMethodListener<ConnectionSecureOkBody> -{ - private static final Logger _logger = Logger.getLogger(ConnectionSecureOkMethodHandler.class); - - private static ConnectionSecureOkMethodHandler _instance = new ConnectionSecureOkMethodHandler(); - - public static ConnectionSecureOkMethodHandler getInstance() - { - return _instance; - } - - private ConnectionSecureOkMethodHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, ConnectionSecureOkBody body, int channelId) throws AMQException - { - Broker<?> broker = stateManager.getBroker(); - AMQProtocolSession session = stateManager.getProtocolSession(); - - SubjectCreator subjectCreator = stateManager.getSubjectCreator(); - - SaslServer ss = session.getSaslServer(); - if (ss == null) - { - throw new AMQException("No SASL context set up in session"); - } - MethodRegistry methodRegistry = session.getMethodRegistry(); - SubjectAuthenticationResult authResult = subjectCreator.authenticate(ss, body.getResponse()); - switch (authResult.getStatus()) - { - case ERROR: - Exception cause = authResult.getCause(); - - _logger.info("Authentication failed:" + (cause == null ? "" : cause.getMessage())); - - // This should be abstracted - stateManager.changeState(AMQState.CONNECTION_CLOSING); - - ConnectionCloseBody connectionCloseBody = - methodRegistry.createConnectionCloseBody(AMQConstant.NOT_ALLOWED.getCode(), - AMQConstant.NOT_ALLOWED.getName(), - body.getClazz(), - body.getMethod()); - - session.writeFrame(connectionCloseBody.generateFrame(0)); - disposeSaslServer(session); - break; - case SUCCESS: - if (_logger.isInfoEnabled()) - { - _logger.info("Connected as: " + authResult.getSubject()); - } - stateManager.changeState(AMQState.CONNECTION_NOT_TUNED); - - int frameMax = broker.getContextValue(Integer.class, Broker.BROKER_FRAME_SIZE); - - if(frameMax <= 0) - { - frameMax = Integer.MAX_VALUE; - } - - ConnectionTuneBody tuneBody = - methodRegistry.createConnectionTuneBody(broker.getConnection_sessionCountLimit(), - frameMax, - broker.getConnection_heartBeatDelay()); - session.writeFrame(tuneBody.generateFrame(0)); - session.setAuthorizedSubject(authResult.getSubject()); - disposeSaslServer(session); - break; - case CONTINUE: - stateManager.changeState(AMQState.CONNECTION_NOT_AUTH); - - ConnectionSecureBody secureBody = methodRegistry.createConnectionSecureBody(authResult.getChallenge()); - session.writeFrame(secureBody.generateFrame(0)); - } - } - - private void disposeSaslServer(AMQProtocolSession ps) - { - SaslServer ss = ps.getSaslServer(); - if (ss != null) - { - ps.setSaslServer(null); - try - { - ss.dispose(); - } - catch (SaslException e) - { - _logger.error("Error disposing of Sasl server: " + e); - } - } - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionStartOkMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionStartOkMethodHandler.java deleted file mode 100644 index e59032b87f..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionStartOkMethodHandler.java +++ /dev/null @@ -1,159 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import javax.security.sasl.SaslException; -import javax.security.sasl.SaslServer; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.ConnectionCloseBody; -import org.apache.qpid.framing.ConnectionSecureBody; -import org.apache.qpid.framing.ConnectionStartOkBody; -import org.apache.qpid.framing.ConnectionTuneBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.model.Broker; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQState; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.security.SubjectCreator; -import org.apache.qpid.server.security.auth.SubjectAuthenticationResult; - - -public class ConnectionStartOkMethodHandler implements StateAwareMethodListener<ConnectionStartOkBody> -{ - private static final Logger _logger = Logger.getLogger(ConnectionStartOkMethodHandler.class); - - private static ConnectionStartOkMethodHandler _instance = new ConnectionStartOkMethodHandler(); - - public static ConnectionStartOkMethodHandler getInstance() - { - return _instance; - } - - private ConnectionStartOkMethodHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, ConnectionStartOkBody body, int channelId) throws AMQException - { - Broker<?> broker = stateManager.getBroker(); - AMQProtocolSession session = stateManager.getProtocolSession(); - - _logger.info("SASL Mechanism selected: " + body.getMechanism()); - _logger.info("Locale selected: " + body.getLocale()); - - SubjectCreator subjectCreator = stateManager.getSubjectCreator(); - SaslServer ss = null; - try - { - ss = subjectCreator.createSaslServer(String.valueOf(body.getMechanism()), session.getLocalFQDN(), session.getPeerPrincipal()); - - if (ss == null) - { - throw body.getConnectionException(AMQConstant.RESOURCE_ERROR, "Unable to create SASL Server:" + body.getMechanism()); - } - - session.setSaslServer(ss); - - final SubjectAuthenticationResult authResult = subjectCreator.authenticate(ss, body.getResponse()); - //save clientProperties - session.setClientProperties(body.getClientProperties()); - - MethodRegistry methodRegistry = session.getMethodRegistry(); - - switch (authResult.getStatus()) - { - case ERROR: - Exception cause = authResult.getCause(); - - _logger.info("Authentication failed:" + (cause == null ? "" : cause.getMessage())); - - stateManager.changeState(AMQState.CONNECTION_CLOSING); - - ConnectionCloseBody closeBody = - methodRegistry.createConnectionCloseBody(AMQConstant.NOT_ALLOWED.getCode(), // replyCode - AMQConstant.NOT_ALLOWED.getName(), - body.getClazz(), - body.getMethod()); - - session.writeFrame(closeBody.generateFrame(0)); - disposeSaslServer(session); - break; - - case SUCCESS: - if (_logger.isInfoEnabled()) - { - _logger.info("Connected as: " + authResult.getSubject()); - } - session.setAuthorizedSubject(authResult.getSubject()); - - stateManager.changeState(AMQState.CONNECTION_NOT_TUNED); - int frameMax = broker.getContextValue(Integer.class, Broker.BROKER_FRAME_SIZE); - - if(frameMax <= 0) - { - frameMax = Integer.MAX_VALUE; - } - - ConnectionTuneBody tuneBody = methodRegistry.createConnectionTuneBody(broker.getConnection_sessionCountLimit(), - frameMax, - broker.getConnection_heartBeatDelay()); - session.writeFrame(tuneBody.generateFrame(0)); - break; - case CONTINUE: - stateManager.changeState(AMQState.CONNECTION_NOT_AUTH); - - ConnectionSecureBody secureBody = methodRegistry.createConnectionSecureBody(authResult.getChallenge()); - session.writeFrame(secureBody.generateFrame(0)); - } - } - catch (SaslException e) - { - disposeSaslServer(session); - throw new AMQException("SASL error: " + e, e); - } - } - - private void disposeSaslServer(AMQProtocolSession ps) - { - SaslServer ss = ps.getSaslServer(); - if (ss != null) - { - ps.setSaslServer(null); - try - { - ss.dispose(); - } - catch (SaslException e) - { - _logger.error("Error disposing of Sasl server: " + e); - } - } - } - -} - - - diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionTuneOkMethodHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionTuneOkMethodHandler.java deleted file mode 100644 index fb4818d3ed..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ConnectionTuneOkMethodHandler.java +++ /dev/null @@ -1,89 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQConnectionException; -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.ConnectionTuneOkBody; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.model.Broker; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQState; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class ConnectionTuneOkMethodHandler implements StateAwareMethodListener<ConnectionTuneOkBody> -{ - private static final Logger _logger = Logger.getLogger(ConnectionTuneOkMethodHandler.class); - - private static ConnectionTuneOkMethodHandler _instance = new ConnectionTuneOkMethodHandler(); - - public static ConnectionTuneOkMethodHandler getInstance() - { - return _instance; - } - - public void methodReceived(AMQStateManager stateManager, ConnectionTuneOkBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - - if (_logger.isDebugEnabled()) - { - _logger.debug(body); - } - stateManager.changeState(AMQState.CONNECTION_NOT_OPENED); - - session.initHeartbeats(body.getHeartbeat()); - - int brokerFrameMax = stateManager.getBroker().getContextValue(Integer.class,Broker.BROKER_FRAME_SIZE); - if(brokerFrameMax <= 0) - { - brokerFrameMax = Integer.MAX_VALUE; - } - - if(body.getFrameMax() > (long) brokerFrameMax) - { - throw new AMQConnectionException(AMQConstant.SYNTAX_ERROR, - "Attempt to set max frame size to " + body.getFrameMax() - + "greater than the broker will allow: " - + brokerFrameMax, - body.getClazz(), body.getMethod(), - body.getMajor(), body.getMinor(),null); - } - else if(body.getFrameMax() > 0 && body.getFrameMax() < AMQConstant.FRAME_MIN_SIZE.getCode()) - { - throw new AMQConnectionException(AMQConstant.SYNTAX_ERROR, - "Attempt to set max frame size to " + body.getFrameMax() - + "which is smaller than the specification definined minimum: " - + AMQConstant.FRAME_MIN_SIZE.getCode(), - body.getClazz(), body.getMethod(), - body.getMajor(), body.getMinor(),null); - } - int frameMax = body.getFrameMax() == 0 ? brokerFrameMax : (int) body.getFrameMax(); - session.setMaxFrameSize(frameMax); - - long maxChannelNumber = body.getChannelMax(); - //0 means no implied limit, except that forced by protocol limitations (0xFFFF) - session.setMaximumNumberOfChannels( maxChannelNumber == 0 ? 0xFFFFL : maxChannelNumber); - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ExchangeBoundHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ExchangeBoundHandler.java deleted file mode 100644 index 2ea638a358..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ExchangeBoundHandler.java +++ /dev/null @@ -1,238 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.ExchangeBoundBody; -import org.apache.qpid.framing.ExchangeBoundOkBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.server.exchange.ExchangeImpl; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.queue.AMQQueue; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - -/** - * @author Apache Software Foundation - * - * - */ -public class ExchangeBoundHandler implements StateAwareMethodListener<ExchangeBoundBody> -{ - private static final ExchangeBoundHandler _instance = new ExchangeBoundHandler(); - - public static final int OK = 0; - - public static final int EXCHANGE_NOT_FOUND = 1; - - public static final int QUEUE_NOT_FOUND = 2; - - public static final int NO_BINDINGS = 3; - - public static final int QUEUE_NOT_BOUND = 4; - - public static final int NO_QUEUE_BOUND_WITH_RK = 5; - - public static final int SPECIFIC_QUEUE_NOT_BOUND_WITH_RK = 6; - - public static ExchangeBoundHandler getInstance() - { - return _instance; - } - - private ExchangeBoundHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, ExchangeBoundBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - VirtualHostImpl virtualHost = session.getVirtualHost(); - MethodRegistry methodRegistry = session.getMethodRegistry(); - - final AMQChannel channel = session.getChannel(channelId); - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - channel.sync(); - - - AMQShortString exchangeName = body.getExchange(); - AMQShortString queueName = body.getQueue(); - AMQShortString routingKey = body.getRoutingKey(); - ExchangeBoundOkBody response; - - if(isDefaultExchange(exchangeName)) - { - if(routingKey == null) - { - if(queueName == null) - { - response = methodRegistry.createExchangeBoundOkBody(virtualHost.getQueues().isEmpty() ? NO_BINDINGS : OK, null); - } - else - { - AMQQueue queue = virtualHost.getQueue(queueName.toString()); - if (queue == null) - { - - response = methodRegistry.createExchangeBoundOkBody(QUEUE_NOT_FOUND, // replyCode - AMQShortString.validValueOf("Queue '" + queueName + "' not found")); // replyText - } - else - { - response = methodRegistry.createExchangeBoundOkBody(OK, null); - } - } - } - else - { - if(queueName == null) - { - response = methodRegistry.createExchangeBoundOkBody(virtualHost.getQueue(routingKey.toString()) == null ? NO_QUEUE_BOUND_WITH_RK : OK, null); - } - else - { - AMQQueue queue = virtualHost.getQueue(queueName.toString()); - if (queue == null) - { - - response = methodRegistry.createExchangeBoundOkBody(QUEUE_NOT_FOUND, // replyCode - AMQShortString.validValueOf("Queue '" + queueName + "' not found")); // replyText - } - else - { - response = methodRegistry.createExchangeBoundOkBody(queueName.equals(routingKey) ? OK : SPECIFIC_QUEUE_NOT_BOUND_WITH_RK, null); - } - } - } - } - else - { - ExchangeImpl exchange = virtualHost.getExchange(exchangeName.toString()); - if (exchange == null) - { - - - response = methodRegistry.createExchangeBoundOkBody(EXCHANGE_NOT_FOUND, - AMQShortString.validValueOf("Exchange '" + exchangeName + "' not found")); - } - else if (routingKey == null) - { - if (queueName == null) - { - if (exchange.hasBindings()) - { - response = methodRegistry.createExchangeBoundOkBody(OK, null); - } - else - { - - response = methodRegistry.createExchangeBoundOkBody(NO_BINDINGS, // replyCode - null); // replyText - } - } - else - { - - AMQQueue queue = virtualHost.getQueue(queueName.toString()); - if (queue == null) - { - - response = methodRegistry.createExchangeBoundOkBody(QUEUE_NOT_FOUND, // replyCode - AMQShortString.validValueOf("Queue '" + queueName + "' not found")); // replyText - } - else - { - if (exchange.isBound(queue)) - { - - response = methodRegistry.createExchangeBoundOkBody(OK, // replyCode - null); // replyText - } - else - { - - response = methodRegistry.createExchangeBoundOkBody(QUEUE_NOT_BOUND, // replyCode - AMQShortString.validValueOf("Queue '" + queueName + "' not bound to exchange '" + exchangeName + "'")); // replyText - } - } - } - } - else if (queueName != null) - { - AMQQueue queue = virtualHost.getQueue(queueName.toString()); - if (queue == null) - { - - response = methodRegistry.createExchangeBoundOkBody(QUEUE_NOT_FOUND, // replyCode - AMQShortString.validValueOf("Queue '" + queueName + "' not found")); // replyText - } - else - { - String bindingKey = body.getRoutingKey() == null ? null : body.getRoutingKey().asString(); - if (exchange.isBound(bindingKey, queue)) - { - - response = methodRegistry.createExchangeBoundOkBody(OK, // replyCode - null); // replyText - } - else - { - - String message = "Queue '" + queueName + "' not bound with routing key '" + - body.getRoutingKey() + "' to exchange '" + exchangeName + "'"; - - response = methodRegistry.createExchangeBoundOkBody(SPECIFIC_QUEUE_NOT_BOUND_WITH_RK, // replyCode - AMQShortString.validValueOf(message)); // replyText - } - } - } - else - { - if (exchange.isBound(body.getRoutingKey() == null ? "" : body.getRoutingKey().asString())) - { - - response = methodRegistry.createExchangeBoundOkBody(OK, // replyCode - null); // replyText - } - else - { - - response = methodRegistry.createExchangeBoundOkBody(NO_QUEUE_BOUND_WITH_RK, // replyCode - AMQShortString.validValueOf("No queue bound with routing key '" + body.getRoutingKey() + - "' to exchange '" + exchangeName + "'")); // replyText - } - } - } - session.writeFrame(response.generateFrame(channelId)); - } - - protected boolean isDefaultExchange(final AMQShortString exchangeName) - { - return exchangeName == null || exchangeName.equals(AMQShortString.EMPTY_STRING); - } - -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ExchangeDeclareHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ExchangeDeclareHandler.java deleted file mode 100644 index 3f48b413ef..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ExchangeDeclareHandler.java +++ /dev/null @@ -1,191 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import java.security.AccessControlException; -import java.util.HashMap; -import java.util.Map; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQConnectionException; -import org.apache.qpid.AMQException; -import org.apache.qpid.exchange.ExchangeDefaults; -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.ExchangeDeclareBody; -import org.apache.qpid.framing.FieldTable; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.exchange.ExchangeImpl; -import org.apache.qpid.server.model.LifetimePolicy; -import org.apache.qpid.server.model.NoFactoryForTypeException; -import org.apache.qpid.server.model.UnknownConfiguredObjectException; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.virtualhost.ExchangeExistsException; -import org.apache.qpid.server.virtualhost.ReservedExchangeNameException; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - -public class ExchangeDeclareHandler implements StateAwareMethodListener<ExchangeDeclareBody> -{ - private static final Logger _logger = Logger.getLogger(ExchangeDeclareHandler.class); - - private static final ExchangeDeclareHandler _instance = new ExchangeDeclareHandler(); - - public static ExchangeDeclareHandler getInstance() - { - return _instance; - } - - private ExchangeDeclareHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, ExchangeDeclareBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - VirtualHostImpl virtualHost = session.getVirtualHost(); - final AMQChannel channel = session.getChannel(channelId); - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - - final AMQShortString exchangeName = body.getExchange(); - if (_logger.isDebugEnabled()) - { - _logger.debug("Request to declare exchange of type " + body.getType() + " with name " + exchangeName); - } - - ExchangeImpl exchange; - - if(isDefaultExchange(exchangeName)) - { - if(!new AMQShortString(ExchangeDefaults.DIRECT_EXCHANGE_CLASS).equals(body.getType())) - { - throw new AMQConnectionException(AMQConstant.NOT_ALLOWED, "Attempt to redeclare default exchange: " - + " of type " - + ExchangeDefaults.DIRECT_EXCHANGE_CLASS - + " to " + body.getType() +".", - body.getClazz(), body.getMethod(), - body.getMajor(), body.getMinor(),null); - } - } - else - { - if (body.getPassive()) - { - exchange = virtualHost.getExchange(exchangeName.toString()); - if(exchange == null) - { - throw body.getChannelException(AMQConstant.NOT_FOUND, "Unknown exchange: " + exchangeName); - } - else if (!(body.getType() == null || body.getType().length() ==0) && !exchange.getType().equals(body.getType().asString())) - { - - throw new AMQConnectionException(AMQConstant.NOT_ALLOWED, "Attempt to redeclare exchange: " + - exchangeName + " of type " + exchange.getType() - + " to " + body.getType() +".",body.getClazz(), body.getMethod(),body.getMajor(),body.getMinor(),null); - } - - } - else - { - try - { - String name = exchangeName == null ? null : exchangeName.intern().toString(); - String type = body.getType() == null ? null : body.getType().intern().toString(); - - Map<String,Object> attributes = new HashMap<String, Object>(); - if(body.getArguments() != null) - { - attributes.putAll(FieldTable.convertToMap(body.getArguments())); - } - attributes.put(org.apache.qpid.server.model.Exchange.ID, null); - attributes.put(org.apache.qpid.server.model.Exchange.NAME,name); - attributes.put(org.apache.qpid.server.model.Exchange.TYPE,type); - attributes.put(org.apache.qpid.server.model.Exchange.DURABLE, body.getDurable()); - attributes.put(org.apache.qpid.server.model.Exchange.LIFETIME_POLICY, - body.getAutoDelete() ? LifetimePolicy.DELETE_ON_NO_LINKS : LifetimePolicy.PERMANENT); - if(!attributes.containsKey(org.apache.qpid.server.model.Exchange.ALTERNATE_EXCHANGE)) - { - attributes.put(org.apache.qpid.server.model.Exchange.ALTERNATE_EXCHANGE, null); - } - exchange = virtualHost.createExchange(attributes); - - } - catch(ReservedExchangeNameException e) - { - throw body.getConnectionException(AMQConstant.NOT_ALLOWED, - "Attempt to declare exchange: " + exchangeName + - " which begins with reserved prefix."); - - } - catch(ExchangeExistsException e) - { - exchange = e.getExistingExchange(); - if(!new AMQShortString(exchange.getType()).equals(body.getType())) - { - throw new AMQConnectionException(AMQConstant.NOT_ALLOWED, "Attempt to redeclare exchange: " - + exchangeName + " of type " - + exchange.getType() - + " to " + body.getType() +".", - body.getClazz(), body.getMethod(), - body.getMajor(), body.getMinor(),null); - } - } - catch(NoFactoryForTypeException e) - { - throw body.getConnectionException(AMQConstant.COMMAND_INVALID, "Unknown exchange: " + exchangeName,e); - } - catch (AccessControlException e) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, e.getMessage()); - } - catch (UnknownConfiguredObjectException e) - { - // note - since 0-8/9/9-1 can't set the alt. exchange this exception should never occur - throw body.getConnectionException(AMQConstant.NOT_FOUND, "Unknown alternate exchange",e); - } - catch (IllegalArgumentException e) - { - throw body.getConnectionException(AMQConstant.COMMAND_INVALID, "Error creating exchange",e); - } - } - } - - if(!body.getNowait()) - { - MethodRegistry methodRegistry = session.getMethodRegistry(); - AMQMethodBody responseBody = methodRegistry.createExchangeDeclareOkBody(); - channel.sync(); - session.writeFrame(responseBody.generateFrame(channelId)); - } - } - - protected boolean isDefaultExchange(final AMQShortString exchangeName) - { - return exchangeName == null || exchangeName.equals(AMQShortString.EMPTY_STRING); - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ExchangeDeleteHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ExchangeDeleteHandler.java deleted file mode 100644 index 1c01a24f63..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ExchangeDeleteHandler.java +++ /dev/null @@ -1,105 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.ExchangeDeleteBody; -import org.apache.qpid.framing.ExchangeDeleteOkBody; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.exchange.ExchangeImpl; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.virtualhost.ExchangeIsAlternateException; -import org.apache.qpid.server.virtualhost.RequiredExchangeException; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - -import java.security.AccessControlException; - -public class ExchangeDeleteHandler implements StateAwareMethodListener<ExchangeDeleteBody> -{ - private static final ExchangeDeleteHandler _instance = new ExchangeDeleteHandler(); - - public static ExchangeDeleteHandler getInstance() - { - return _instance; - } - - private ExchangeDeleteHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, ExchangeDeleteBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - VirtualHostImpl virtualHost = session.getVirtualHost(); - final AMQChannel channel = session.getChannel(channelId); - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - channel.sync(); - try - { - - if(isDefaultExchange(body.getExchange())) - { - throw body.getConnectionException(AMQConstant.NOT_ALLOWED, "Default Exchange cannot be deleted"); - } - - final String exchangeName = body.getExchange().toString(); - - final ExchangeImpl exchange = virtualHost.getExchange(exchangeName); - if(exchange == null) - { - throw body.getChannelException(AMQConstant.NOT_FOUND, "No such exchange: " + body.getExchange()); - } - - virtualHost.removeExchange(exchange, !body.getIfUnused()); - - ExchangeDeleteOkBody responseBody = session.getMethodRegistry().createExchangeDeleteOkBody(); - - session.writeFrame(responseBody.generateFrame(channelId)); - } - - catch (ExchangeIsAlternateException e) - { - throw body.getChannelException(AMQConstant.NOT_ALLOWED, "Exchange in use as an alternate exchange"); - - } - catch (RequiredExchangeException e) - { - throw body.getChannelException(AMQConstant.NOT_ALLOWED, "Exchange '"+body.getExchange()+"' cannot be deleted"); - } - catch (AccessControlException e) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, e.getMessage()); - } - } - - - protected boolean isDefaultExchange(final AMQShortString exchangeName) - { - return exchangeName == null || exchangeName.equals(AMQShortString.EMPTY_STRING); - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/OnCurrentThreadExecutor.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/OnCurrentThreadExecutor.java deleted file mode 100644 index 6ff511ea30..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/OnCurrentThreadExecutor.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import java.util.concurrent.Executor; - -/** - * An executor that executes the task on the current thread. - */ -public class OnCurrentThreadExecutor implements Executor -{ - public void execute(Runnable command) - { - command.run(); - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueBindHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueBindHandler.java deleted file mode 100644 index 0140d2ec7e..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueBindHandler.java +++ /dev/null @@ -1,157 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import java.security.AccessControlException; -import java.util.Map; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.exchange.ExchangeDefaults; -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.FieldTable; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.QueueBindBody; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.exchange.ExchangeImpl; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.queue.AMQQueue; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - -public class QueueBindHandler implements StateAwareMethodListener<QueueBindBody> -{ - private static final Logger _log = Logger.getLogger(QueueBindHandler.class); - - private static final QueueBindHandler _instance = new QueueBindHandler(); - - public static QueueBindHandler getInstance() - { - return _instance; - } - - private QueueBindHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, QueueBindBody body, int channelId) throws AMQException - { - AMQProtocolSession protocolConnection = stateManager.getProtocolSession(); - VirtualHostImpl virtualHost = protocolConnection.getVirtualHost(); - AMQChannel channel = protocolConnection.getChannel(channelId); - - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - - final AMQQueue queue; - final AMQShortString routingKey; - - final AMQShortString queueName = body.getQueue(); - - if (queueName == null) - { - - queue = channel.getDefaultQueue(); - - if (queue == null) - { - throw body.getChannelException(AMQConstant.NOT_FOUND, "No default queue defined on channel and queue was null"); - } - - if (body.getRoutingKey() == null) - { - routingKey = AMQShortString.valueOf(queue.getName()); - } - else - { - routingKey = body.getRoutingKey().intern(); - } - } - else - { - queue = virtualHost.getQueue(queueName.toString()); - routingKey = body.getRoutingKey() == null ? AMQShortString.EMPTY_STRING : body.getRoutingKey().intern(); - } - - if (queue == null) - { - throw body.getChannelException(AMQConstant.NOT_FOUND, "Queue " + queueName + " does not exist."); - } - - if(isDefaultExchange(body.getExchange())) - { - throw body.getConnectionException(AMQConstant.NOT_ALLOWED, "Cannot bind the queue " + queueName + " to the default exchange"); - } - - final String exchangeName = body.getExchange().toString(); - - final ExchangeImpl exch = virtualHost.getExchange(exchangeName); - if (exch == null) - { - throw body.getChannelException(AMQConstant.NOT_FOUND, "Exchange " + exchangeName + " does not exist."); - } - - - try - { - - Map<String,Object> arguments = FieldTable.convertToMap(body.getArguments()); - String bindingKey = String.valueOf(routingKey); - - if (!exch.isBound(bindingKey, arguments, queue)) - { - - if(!exch.addBinding(bindingKey, queue, arguments) && ExchangeDefaults.TOPIC_EXCHANGE_CLASS.equals(exch.getType())) - { - exch.replaceBinding(bindingKey, queue, arguments); - } - } - } - catch (AccessControlException e) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, e.getMessage()); - } - - if (_log.isInfoEnabled()) - { - _log.info("Binding queue " + queue + " to exchange " + exch + " with routing key " + routingKey); - } - if (!body.getNowait()) - { - channel.sync(); - MethodRegistry methodRegistry = protocolConnection.getMethodRegistry(); - AMQMethodBody responseBody = methodRegistry.createQueueBindOkBody(); - protocolConnection.writeFrame(responseBody.generateFrame(channelId)); - - } - } - - protected boolean isDefaultExchange(final AMQShortString exchangeName) - { - return exchangeName == null || exchangeName.equals(AMQShortString.EMPTY_STRING); - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueDeclareHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueDeclareHandler.java deleted file mode 100644 index ef8d01d89f..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueDeclareHandler.java +++ /dev/null @@ -1,221 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import java.security.AccessControlException; -import java.util.Map; -import java.util.UUID; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.FieldTable; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.QueueDeclareBody; -import org.apache.qpid.framing.QueueDeclareOkBody; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.model.ExclusivityPolicy; -import org.apache.qpid.server.model.LifetimePolicy; -import org.apache.qpid.server.model.Queue; -import org.apache.qpid.server.protocol.AMQSessionModel; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.queue.AMQQueue; -import org.apache.qpid.server.queue.QueueArgumentsConverter; -import org.apache.qpid.server.virtualhost.QueueExistsException; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - -public class QueueDeclareHandler implements StateAwareMethodListener<QueueDeclareBody> -{ - private static final Logger _logger = Logger.getLogger(QueueDeclareHandler.class); - - private static final QueueDeclareHandler _instance = new QueueDeclareHandler(); - - public static QueueDeclareHandler getInstance() - { - return _instance; - } - - public void methodReceived(AMQStateManager stateManager, QueueDeclareBody body, int channelId) throws AMQException - { - final AMQProtocolSession protocolConnection = stateManager.getProtocolSession(); - final AMQSessionModel session = protocolConnection.getChannel(channelId); - VirtualHostImpl virtualHost = protocolConnection.getVirtualHost(); - - final AMQShortString queueName; - - // if we aren't given a queue name, we create one which we return to the client - if ((body.getQueue() == null) || (body.getQueue().length() == 0)) - { - queueName = createName(); - } - else - { - queueName = body.getQueue().intern(); - } - - AMQQueue queue; - - //TODO: do we need to check that the queue already exists with exactly the same "configuration"? - - AMQChannel channel = protocolConnection.getChannel(channelId); - - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - - if(body.getPassive()) - { - queue = virtualHost.getQueue(queueName.toString()); - if (queue == null) - { - String msg = "Queue: " + queueName + " not found on VirtualHost(" + virtualHost + ")."; - throw body.getChannelException(AMQConstant.NOT_FOUND, msg); - } - else - { - if (!queue.verifySessionAccess(channel)) - { - throw body.getConnectionException(AMQConstant.NOT_ALLOWED, - "Queue " + queue.getName() + " is exclusive, but not created on this Connection."); - } - - //set this as the default queue on the channel: - channel.setDefaultQueue(queue); - } - } - else - { - - try - { - - queue = createQueue(channel, queueName, body, virtualHost, protocolConnection); - - } - catch(QueueExistsException qe) - { - - queue = qe.getExistingQueue(); - - if (!queue.verifySessionAccess(channel)) - { - throw body.getConnectionException(AMQConstant.NOT_ALLOWED, - "Queue " + queue.getName() + " is exclusive, but not created on this Connection."); - } - else if(queue.isExclusive() != body.getExclusive()) - { - - throw body.getChannelException(AMQConstant.ALREADY_EXISTS, - "Cannot re-declare queue '" + queue.getName() + "' with different exclusivity (was: " - + queue.isExclusive() + " requested " + body.getExclusive() + ")"); - } - else if((body.getAutoDelete() && queue.getLifetimePolicy() != LifetimePolicy.DELETE_ON_NO_OUTBOUND_LINKS) - || (!body.getAutoDelete() && queue.getLifetimePolicy() != ((body.getExclusive() && !body.getDurable()) ? LifetimePolicy.DELETE_ON_CONNECTION_CLOSE : LifetimePolicy.PERMANENT))) - { - throw body.getChannelException(AMQConstant.ALREADY_EXISTS, - "Cannot re-declare queue '" + queue.getName() + "' with different lifetime policy (was: " - + queue.getLifetimePolicy() + " requested autodelete: " + body.getAutoDelete() + ")"); - } - else if(queue.isDurable() != body.getDurable()) - { - throw body.getChannelException(AMQConstant.ALREADY_EXISTS, - "Cannot re-declare queue '" + queue.getName() + "' with different durability (was: " - + queue.isDurable() + " requested " + body.getDurable() + ")"); - } - - } - catch (AccessControlException e) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, e.getMessage()); - } - - //set this as the default queue on the channel: - channel.setDefaultQueue(queue); - } - - if (!body.getNowait()) - { - channel.sync(); - MethodRegistry methodRegistry = protocolConnection.getMethodRegistry(); - QueueDeclareOkBody responseBody = - methodRegistry.createQueueDeclareOkBody(queueName, - queue.getQueueDepthMessages(), - queue.getConsumerCount()); - protocolConnection.writeFrame(responseBody.generateFrame(channelId)); - - _logger.info("Queue " + queueName + " declared successfully"); - } - } - - protected AMQShortString createName() - { - return new AMQShortString("tmp_" + UUID.randomUUID()); - } - - protected AMQQueue createQueue(final AMQChannel channel, final AMQShortString queueName, - QueueDeclareBody body, - final VirtualHostImpl virtualHost, - final AMQProtocolSession session) - throws AMQException, QueueExistsException - { - - final boolean durable = body.getDurable(); - final boolean autoDelete = body.getAutoDelete(); - final boolean exclusive = body.getExclusive(); - - - Map<String, Object> attributes = - QueueArgumentsConverter.convertWireArgsToModel(FieldTable.convertToMap(body.getArguments())); - final String queueNameString = AMQShortString.toString(queueName); - attributes.put(Queue.NAME, queueNameString); - attributes.put(Queue.ID, UUID.randomUUID()); - attributes.put(Queue.DURABLE, durable); - - LifetimePolicy lifetimePolicy; - ExclusivityPolicy exclusivityPolicy; - - if(exclusive) - { - lifetimePolicy = autoDelete - ? LifetimePolicy.DELETE_ON_NO_OUTBOUND_LINKS - : durable ? LifetimePolicy.PERMANENT : LifetimePolicy.DELETE_ON_CONNECTION_CLOSE; - exclusivityPolicy = durable ? ExclusivityPolicy.CONTAINER : ExclusivityPolicy.CONNECTION; - } - else - { - lifetimePolicy = autoDelete ? LifetimePolicy.DELETE_ON_NO_OUTBOUND_LINKS : LifetimePolicy.PERMANENT; - exclusivityPolicy = ExclusivityPolicy.NONE; - } - - attributes.put(Queue.EXCLUSIVE, exclusivityPolicy); - attributes.put(Queue.LIFETIME_POLICY, lifetimePolicy); - - - final AMQQueue queue = virtualHost.createQueue(attributes); - - return queue; - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueDeleteHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueDeleteHandler.java deleted file mode 100644 index 84efcb68b8..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueDeleteHandler.java +++ /dev/null @@ -1,128 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.QueueDeleteBody; -import org.apache.qpid.framing.QueueDeleteOkBody; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.queue.AMQQueue; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.store.DurableConfigurationStore; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - -import java.security.AccessControlException; - -public class QueueDeleteHandler implements StateAwareMethodListener<QueueDeleteBody> -{ - private static final QueueDeleteHandler _instance = new QueueDeleteHandler(); - - public static QueueDeleteHandler getInstance() - { - return _instance; - } - - private final boolean _failIfNotFound; - - public QueueDeleteHandler() - { - this(true); - } - - public QueueDeleteHandler(boolean failIfNotFound) - { - _failIfNotFound = failIfNotFound; - - } - - public void methodReceived(AMQStateManager stateManager, QueueDeleteBody body, int channelId) throws AMQException - { - AMQProtocolSession protocolConnection = stateManager.getProtocolSession(); - VirtualHostImpl virtualHost = protocolConnection.getVirtualHost(); - DurableConfigurationStore store = virtualHost.getDurableConfigurationStore(); - - - AMQChannel channel = protocolConnection.getChannel(channelId); - - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - channel.sync(); - AMQQueue queue; - if (body.getQueue() == null) - { - - //get the default queue on the channel: - queue = channel.getDefaultQueue(); - } - else - { - queue = virtualHost.getQueue(body.getQueue().toString()); - } - - if (queue == null) - { - if (_failIfNotFound) - { - throw body.getChannelException(AMQConstant.NOT_FOUND, "Queue " + body.getQueue() + " does not exist."); - } - } - else - { - if (body.getIfEmpty() && !queue.isEmpty()) - { - throw body.getChannelException(AMQConstant.IN_USE, "Queue: " + body.getQueue() + " is not empty."); - } - else if (body.getIfUnused() && !queue.isUnused()) - { - // TODO - Error code - throw body.getChannelException(AMQConstant.IN_USE, "Queue: " + body.getQueue() + " is still used."); - } - else - { - if (!queue.verifySessionAccess(channel)) - { - throw body.getConnectionException(AMQConstant.NOT_ALLOWED, - "Queue " + queue.getName() + " is exclusive, but not created on this Connection."); - } - - int purged = 0; - try - { - purged = virtualHost.removeQueue(queue); - } - catch (AccessControlException e) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, e.getMessage()); - } - - MethodRegistry methodRegistry = protocolConnection.getMethodRegistry(); - QueueDeleteOkBody responseBody = methodRegistry.createQueueDeleteOkBody(purged); - protocolConnection.writeFrame(responseBody.generateFrame(channelId)); - } - } - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueuePurgeHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueuePurgeHandler.java deleted file mode 100644 index 68ecf0324c..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueuePurgeHandler.java +++ /dev/null @@ -1,125 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - * - */ - -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.QueuePurgeBody; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.queue.AMQQueue; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - -import java.security.AccessControlException; - -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(); - VirtualHostImpl virtualHost = protocolConnection.getVirtualHost(); - - AMQChannel channel = protocolConnection.getChannel(channelId); - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - AMQQueue queue; - if(body.getQueue() == null) - { - - //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 = virtualHost.getQueue(body.getQueue().toString()); - } - - if(queue == null) - { - if(_failIfNotFound) - { - throw body.getChannelException(AMQConstant.NOT_FOUND, "Queue " + body.getQueue() + " does not exist."); - } - } - else - { - if (!queue.verifySessionAccess(channel)) - { - throw body.getConnectionException(AMQConstant.NOT_ALLOWED, - "Queue is exclusive, but not created on this Connection."); - } - - long purged = 0; - try - { - purged = queue.clearQueue(); - } - catch (AccessControlException e) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, e.getMessage()); - } - - - if(!body.getNowait()) - { - channel.sync(); - MethodRegistry methodRegistry = protocolConnection.getMethodRegistry(); - AMQMethodBody responseBody = methodRegistry.createQueuePurgeOkBody(purged); - protocolConnection.writeFrame(responseBody.generateFrame(channelId)); - - } - } - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueUnbindHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueUnbindHandler.java deleted file mode 100644 index 4e2d1bc8a2..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueUnbindHandler.java +++ /dev/null @@ -1,154 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.QueueUnbindBody; -import org.apache.qpid.framing.amqp_0_9.MethodRegistry_0_9; -import org.apache.qpid.framing.amqp_0_91.MethodRegistry_0_91; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.server.exchange.ExchangeImpl; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.queue.AMQQueue; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; -import org.apache.qpid.server.virtualhost.VirtualHostImpl; - -import java.security.AccessControlException; - -public class QueueUnbindHandler implements StateAwareMethodListener<QueueUnbindBody> -{ - private static final Logger _log = Logger.getLogger(QueueUnbindHandler.class); - - private static final QueueUnbindHandler _instance = new QueueUnbindHandler(); - - public static QueueUnbindHandler getInstance() - { - return _instance; - } - - private QueueUnbindHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, QueueUnbindBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - VirtualHostImpl virtualHost = session.getVirtualHost(); - - final AMQQueue queue; - final AMQShortString routingKey; - - - AMQChannel channel = session.getChannel(channelId); - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - - if (body.getQueue() == null) - { - - queue = channel.getDefaultQueue(); - - if (queue == null) - { - throw body.getChannelException(AMQConstant.NOT_FOUND, "No default queue defined on channel and queue was null"); - } - - routingKey = body.getRoutingKey() == null ? null : body.getRoutingKey().intern(false); - - } - else - { - queue = virtualHost.getQueue(body.getQueue().toString()); - routingKey = body.getRoutingKey() == null ? null : body.getRoutingKey().intern(false); - } - - if (queue == null) - { - throw body.getChannelException(AMQConstant.NOT_FOUND, "Queue " + body.getQueue() + " does not exist."); - } - - if(isDefaultExchange(body.getExchange())) - { - throw body.getConnectionException(AMQConstant.NOT_ALLOWED, "Cannot unbind the queue " + queue.getName() + " from the default exchange"); - } - - final ExchangeImpl exch = virtualHost.getExchange(body.getExchange() == null ? null : body.getExchange().toString()); - if (exch == null) - { - throw body.getChannelException(AMQConstant.NOT_FOUND, "Exchange " + body.getExchange() + " does not exist."); - } - - if(!exch.hasBinding(String.valueOf(routingKey), queue)) - { - throw body.getChannelException(AMQConstant.NOT_FOUND,"No such binding"); - } - else - { - try - { - exch.deleteBinding(String.valueOf(routingKey), queue); - } - catch (AccessControlException e) - { - throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, e.getMessage()); - } - } - - - if (_log.isInfoEnabled()) - { - _log.info("Binding queue " + queue + " to exchange " + exch + " with routing key " + routingKey); - } - - final MethodRegistry registry = session.getMethodRegistry(); - final AMQMethodBody responseBody; - if (registry instanceof MethodRegistry_0_9) - { - responseBody = ((MethodRegistry_0_9)registry).createQueueUnbindOkBody(); - } - else if (registry instanceof MethodRegistry_0_91) - { - responseBody = ((MethodRegistry_0_91)registry).createQueueUnbindOkBody(); - } - else - { - // 0-8 does not support QueueUnbind - throw new AMQException(AMQConstant.COMMAND_INVALID, "QueueUnbind not present in AMQP version: " + session.getProtocolVersion(), null); - } - channel.sync(); - session.writeFrame(responseBody.generateFrame(channelId)); - } - - protected boolean isDefaultExchange(final AMQShortString exchangeName) - { - return exchangeName == null || exchangeName.equals(AMQShortString.EMPTY_STRING); - } - -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ServerMethodDispatcherImpl.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ServerMethodDispatcherImpl.java deleted file mode 100644 index 43e97c0cb6..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ServerMethodDispatcherImpl.java +++ /dev/null @@ -1,574 +0,0 @@ -/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
- */
-package org.apache.qpid.server.protocol.v0_8.handler;
-
-import org.apache.qpid.AMQException;
-import org.apache.qpid.framing.*;
-import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager;
-
-import java.util.HashMap;
-import java.util.Map;
-
-public class ServerMethodDispatcherImpl implements MethodDispatcher
-{
- private final AMQStateManager _stateManager;
-
- private static interface DispatcherFactory
- {
- public MethodDispatcher createMethodDispatcher(AMQStateManager stateManager);
- }
-
- private static final Map<ProtocolVersion, DispatcherFactory> _dispatcherFactories =
- new HashMap<ProtocolVersion, DispatcherFactory>();
-
-
- static
- {
- _dispatcherFactories.put(ProtocolVersion.v8_0,
- new DispatcherFactory()
- {
- public MethodDispatcher createMethodDispatcher(AMQStateManager stateManager)
- {
- return new ServerMethodDispatcherImpl_8_0(stateManager);
- }
- });
-
- _dispatcherFactories.put(ProtocolVersion.v0_9,
- new DispatcherFactory()
- {
- public MethodDispatcher createMethodDispatcher(AMQStateManager stateManager)
- {
- return new ServerMethodDispatcherImpl_0_9(stateManager);
- }
- });
- _dispatcherFactories.put(ProtocolVersion.v0_91,
- new DispatcherFactory()
- {
- public MethodDispatcher createMethodDispatcher(AMQStateManager stateManager)
- {
- return new ServerMethodDispatcherImpl_0_91(stateManager);
- }
- });
-
- }
-
-
- private static final AccessRequestHandler _accessRequestHandler = AccessRequestHandler.getInstance();
- private static final ChannelCloseHandler _channelCloseHandler = ChannelCloseHandler.getInstance();
- private static final ChannelOpenHandler _channelOpenHandler = ChannelOpenHandler.getInstance();
- private static final ChannelCloseOkHandler _channelCloseOkHandler = ChannelCloseOkHandler.getInstance();
- private static final ConnectionCloseMethodHandler _connectionCloseMethodHandler = ConnectionCloseMethodHandler.getInstance();
- private static final ConnectionCloseOkMethodHandler _connectionCloseOkMethodHandler = ConnectionCloseOkMethodHandler.getInstance();
- private static final ConnectionOpenMethodHandler _connectionOpenMethodHandler = ConnectionOpenMethodHandler.getInstance();
- private static final ConnectionTuneOkMethodHandler _connectionTuneOkMethodHandler = ConnectionTuneOkMethodHandler.getInstance();
- private static final ConnectionSecureOkMethodHandler _connectionSecureOkMethodHandler = ConnectionSecureOkMethodHandler.getInstance();
- private static final ConnectionStartOkMethodHandler _connectionStartOkMethodHandler = ConnectionStartOkMethodHandler.getInstance();
- private static final ExchangeDeclareHandler _exchangeDeclareHandler = ExchangeDeclareHandler.getInstance();
- private static final ExchangeDeleteHandler _exchangeDeleteHandler = ExchangeDeleteHandler.getInstance();
- private static final ExchangeBoundHandler _exchangeBoundHandler = ExchangeBoundHandler.getInstance();
- private static final BasicAckMethodHandler _basicAckMethodHandler = BasicAckMethodHandler.getInstance();
- private static final BasicRecoverMethodHandler _basicRecoverMethodHandler = BasicRecoverMethodHandler.getInstance();
- private static final BasicConsumeMethodHandler _basicConsumeMethodHandler = BasicConsumeMethodHandler.getInstance();
- private static final BasicGetMethodHandler _basicGetMethodHandler = BasicGetMethodHandler.getInstance();
- private static final BasicCancelMethodHandler _basicCancelMethodHandler = BasicCancelMethodHandler.getInstance();
- private static final BasicPublishMethodHandler _basicPublishMethodHandler = BasicPublishMethodHandler.getInstance();
- private static final BasicQosHandler _basicQosHandler = BasicQosHandler.getInstance();
- private static final QueueBindHandler _queueBindHandler = QueueBindHandler.getInstance();
- private static final QueueDeclareHandler _queueDeclareHandler = QueueDeclareHandler.getInstance();
- private static final QueueDeleteHandler _queueDeleteHandler = QueueDeleteHandler.getInstance();
- private static final QueuePurgeHandler _queuePurgeHandler = QueuePurgeHandler.getInstance();
- private static final ChannelFlowHandler _channelFlowHandler = ChannelFlowHandler.getInstance();
- private static final TxSelectHandler _txSelectHandler = TxSelectHandler.getInstance();
- private static final TxCommitHandler _txCommitHandler = TxCommitHandler.getInstance();
- private static final TxRollbackHandler _txRollbackHandler = TxRollbackHandler.getInstance();
- private static final BasicRejectMethodHandler _basicRejectMethodHandler = BasicRejectMethodHandler.getInstance();
-
-
-
- public static MethodDispatcher createMethodDispatcher(AMQStateManager stateManager, ProtocolVersion protocolVersion)
- {
- return _dispatcherFactories.get(protocolVersion).createMethodDispatcher(stateManager);
- }
-
-
- public ServerMethodDispatcherImpl(AMQStateManager stateManager)
- {
- _stateManager = stateManager;
- }
-
-
- protected AMQStateManager getStateManager()
- {
- return _stateManager;
- }
-
-
-
- public boolean dispatchAccessRequest(AccessRequestBody body, int channelId) throws AMQException
- {
- _accessRequestHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchBasicAck(BasicAckBody body, int channelId) throws AMQException
- {
- _basicAckMethodHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchBasicCancel(BasicCancelBody body, int channelId) throws AMQException
- {
- _basicCancelMethodHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchBasicConsume(BasicConsumeBody body, int channelId) throws AMQException
- {
- _basicConsumeMethodHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchBasicGet(BasicGetBody body, int channelId) throws AMQException
- {
- _basicGetMethodHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchBasicPublish(BasicPublishBody body, int channelId) throws AMQException
- {
- _basicPublishMethodHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchBasicQos(BasicQosBody body, int channelId) throws AMQException
- {
- _basicQosHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchBasicRecover(BasicRecoverBody body, int channelId) throws AMQException
- {
- _basicRecoverMethodHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchBasicReject(BasicRejectBody body, int channelId) throws AMQException
- {
- _basicRejectMethodHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchChannelOpen(ChannelOpenBody body, int channelId) throws AMQException
- {
- _channelOpenHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
-
- public boolean dispatchAccessRequestOk(AccessRequestOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchBasicCancelOk(BasicCancelOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchBasicConsumeOk(BasicConsumeOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchBasicDeliver(BasicDeliverBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchBasicGetEmpty(BasicGetEmptyBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchBasicGetOk(BasicGetOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchBasicQosOk(BasicQosOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchBasicReturn(BasicReturnBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchChannelClose(ChannelCloseBody body, int channelId) throws AMQException
- {
- _channelCloseHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
-
- public boolean dispatchChannelCloseOk(ChannelCloseOkBody body, int channelId) throws AMQException
- {
- _channelCloseOkHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
-
- public boolean dispatchChannelFlow(ChannelFlowBody body, int channelId) throws AMQException
- {
- _channelFlowHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchChannelFlowOk(ChannelFlowOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchChannelOpenOk(ChannelOpenOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
-
- public boolean dispatchConnectionOpen(ConnectionOpenBody body, int channelId) throws AMQException
- {
- _connectionOpenMethodHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
-
- public boolean dispatchConnectionClose(ConnectionCloseBody body, int channelId) throws AMQException
- {
- _connectionCloseMethodHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
-
- public boolean dispatchConnectionCloseOk(ConnectionCloseOkBody body, int channelId) throws AMQException
- {
- _connectionCloseOkMethodHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchConnectionOpenOk(ConnectionOpenOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchConnectionRedirect(ConnectionRedirectBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchConnectionSecure(ConnectionSecureBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchConnectionStart(ConnectionStartBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchConnectionTune(ConnectionTuneBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchDtxSelectOk(DtxSelectOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchDtxStartOk(DtxStartOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchExchangeBoundOk(ExchangeBoundOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchExchangeDeclareOk(ExchangeDeclareOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchExchangeDeleteOk(ExchangeDeleteOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchFileCancelOk(FileCancelOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchFileConsumeOk(FileConsumeOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchFileDeliver(FileDeliverBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchFileOpen(FileOpenBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchFileOpenOk(FileOpenOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchFileQosOk(FileQosOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchFileReturn(FileReturnBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchFileStage(FileStageBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchQueueBindOk(QueueBindOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchQueueDeclareOk(QueueDeclareOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchQueueDeleteOk(QueueDeleteOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchQueuePurgeOk(QueuePurgeOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchStreamCancelOk(StreamCancelOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchStreamConsumeOk(StreamConsumeOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchStreamDeliver(StreamDeliverBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchStreamQosOk(StreamQosOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchStreamReturn(StreamReturnBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchTxCommitOk(TxCommitOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchTxRollbackOk(TxRollbackOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchTxSelectOk(TxSelectOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
-
- public boolean dispatchConnectionSecureOk(ConnectionSecureOkBody body, int channelId) throws AMQException
- {
- _connectionSecureOkMethodHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchConnectionStartOk(ConnectionStartOkBody body, int channelId) throws AMQException
- {
- _connectionStartOkMethodHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchConnectionTuneOk(ConnectionTuneOkBody body, int channelId) throws AMQException
- {
- _connectionTuneOkMethodHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchDtxSelect(DtxSelectBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchDtxStart(DtxStartBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchExchangeBound(ExchangeBoundBody body, int channelId) throws AMQException
- {
- _exchangeBoundHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchExchangeDeclare(ExchangeDeclareBody body, int channelId) throws AMQException
- {
- _exchangeDeclareHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchExchangeDelete(ExchangeDeleteBody body, int channelId) throws AMQException
- {
- _exchangeDeleteHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchFileAck(FileAckBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchFileCancel(FileCancelBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchFileConsume(FileConsumeBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchFilePublish(FilePublishBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchFileQos(FileQosBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchFileReject(FileRejectBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchQueueBind(QueueBindBody body, int channelId) throws AMQException
- {
- _queueBindHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchQueueDeclare(QueueDeclareBody body, int channelId) throws AMQException
- {
- _queueDeclareHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchQueueDelete(QueueDeleteBody body, int channelId) throws AMQException
- {
- _queueDeleteHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchQueuePurge(QueuePurgeBody body, int channelId) throws AMQException
- {
- _queuePurgeHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchStreamCancel(StreamCancelBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchStreamConsume(StreamConsumeBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchStreamPublish(StreamPublishBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchStreamQos(StreamQosBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchTunnelRequest(TunnelRequestBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchTxCommit(TxCommitBody body, int channelId) throws AMQException
- {
- _txCommitHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchTxRollback(TxRollbackBody body, int channelId) throws AMQException
- {
- _txRollbackHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
- public boolean dispatchTxSelect(TxSelectBody body, int channelId) throws AMQException
- {
- _txSelectHandler.methodReceived(_stateManager, body, channelId);
- return true;
- }
-
-
-
-
-}
diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ServerMethodDispatcherImpl_0_9.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ServerMethodDispatcherImpl_0_9.java deleted file mode 100644 index 1ee6d732c2..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ServerMethodDispatcherImpl_0_9.java +++ /dev/null @@ -1,164 +0,0 @@ -/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
- */
-package org.apache.qpid.server.protocol.v0_8.handler;
-
-
-import org.apache.qpid.AMQException;
-import org.apache.qpid.framing.*;
-import org.apache.qpid.framing.amqp_0_9.MethodDispatcher_0_9;
-import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager;
-
-
-
-public class ServerMethodDispatcherImpl_0_9
- extends ServerMethodDispatcherImpl
- implements MethodDispatcher_0_9
-
-{
-
- private static final BasicRecoverSyncMethodHandler _basicRecoverSyncMethodHandler =
- BasicRecoverSyncMethodHandler.getInstance();
- private static final QueueUnbindHandler _queueUnbindHandler =
- QueueUnbindHandler.getInstance();
-
-
- public ServerMethodDispatcherImpl_0_9(AMQStateManager stateManager)
- {
- super(stateManager);
- }
-
- public boolean dispatchBasicRecoverSync(BasicRecoverSyncBody body, int channelId) throws AMQException
- {
- _basicRecoverSyncMethodHandler.methodReceived(getStateManager(), body, channelId);
- return true;
- }
-
- public boolean dispatchBasicRecoverSyncOk(BasicRecoverSyncOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchChannelOk(ChannelOkBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchChannelPing(ChannelPingBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchChannelPong(ChannelPongBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchChannelResume(ChannelResumeBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageAppend(MessageAppendBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageCancel(MessageCancelBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageCheckpoint(MessageCheckpointBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageClose(MessageCloseBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageConsume(MessageConsumeBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageEmpty(MessageEmptyBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageGet(MessageGetBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageOffset(MessageOffsetBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageOk(MessageOkBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageOpen(MessageOpenBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageQos(MessageQosBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageRecover(MessageRecoverBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageReject(MessageRejectBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageResume(MessageResumeBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageTransfer(MessageTransferBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchQueueUnbindOk(QueueUnbindOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchQueueUnbind(QueueUnbindBody body, int channelId) throws AMQException
- {
- _queueUnbindHandler.methodReceived(getStateManager(),body,channelId);
- return true;
- }
-}
diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ServerMethodDispatcherImpl_0_91.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ServerMethodDispatcherImpl_0_91.java deleted file mode 100644 index b11b9cff2b..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ServerMethodDispatcherImpl_0_91.java +++ /dev/null @@ -1,168 +0,0 @@ -/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
- */
-package org.apache.qpid.server.protocol.v0_8.handler;
-
-
-import org.apache.qpid.AMQException;
-import org.apache.qpid.framing.*;
-import org.apache.qpid.framing.amqp_0_91.MethodDispatcher_0_91;
-import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager;
-
-
-public class ServerMethodDispatcherImpl_0_91
- extends ServerMethodDispatcherImpl
- implements MethodDispatcher_0_91
-
-{
-
- private static final BasicRecoverSyncMethodHandler _basicRecoverSyncMethodHandler =
- BasicRecoverSyncMethodHandler.getInstance();
- private static final QueueUnbindHandler _queueUnbindHandler =
- QueueUnbindHandler.getInstance();
-
-
- public ServerMethodDispatcherImpl_0_91(AMQStateManager stateManager)
- {
- super(stateManager);
- }
-
- public boolean dispatchBasicRecoverSync(BasicRecoverSyncBody body, int channelId) throws AMQException
- {
- _basicRecoverSyncMethodHandler.methodReceived(getStateManager(), body, channelId);
- return true;
- }
-
- public boolean dispatchBasicRecoverSyncOk(BasicRecoverSyncOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchChannelOk(ChannelOkBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchChannelPing(ChannelPingBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchChannelPong(ChannelPongBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchChannelResume(ChannelResumeBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageAppend(MessageAppendBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageCancel(MessageCancelBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageCheckpoint(MessageCheckpointBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageClose(MessageCloseBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageConsume(MessageConsumeBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageEmpty(MessageEmptyBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageGet(MessageGetBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageOffset(MessageOffsetBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageOk(MessageOkBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageOpen(MessageOpenBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageQos(MessageQosBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageRecover(MessageRecoverBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageReject(MessageRejectBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageResume(MessageResumeBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchMessageTransfer(MessageTransferBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchBasicRecoverOk(BasicRecoverOkBody body, int channelId) throws AMQException
- {
- return false; //To change body of implemented methods use File | Settings | File Templates.
- }
-
- public boolean dispatchQueueUnbindOk(QueueUnbindOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchQueueUnbind(QueueUnbindBody body, int channelId) throws AMQException
- {
- _queueUnbindHandler.methodReceived(getStateManager(),body,channelId);
- return true;
- }
-}
diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ServerMethodDispatcherImpl_8_0.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ServerMethodDispatcherImpl_8_0.java deleted file mode 100644 index f05219712f..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ServerMethodDispatcherImpl_8_0.java +++ /dev/null @@ -1,95 +0,0 @@ -/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
- */
-package org.apache.qpid.server.protocol.v0_8.handler;
-
-import org.apache.qpid.AMQException;
-import org.apache.qpid.framing.BasicRecoverOkBody;
-import org.apache.qpid.framing.ChannelAlertBody;
-import org.apache.qpid.framing.TestContentBody;
-import org.apache.qpid.framing.TestContentOkBody;
-import org.apache.qpid.framing.TestIntegerBody;
-import org.apache.qpid.framing.TestIntegerOkBody;
-import org.apache.qpid.framing.TestStringBody;
-import org.apache.qpid.framing.TestStringOkBody;
-import org.apache.qpid.framing.TestTableBody;
-import org.apache.qpid.framing.TestTableOkBody;
-import org.apache.qpid.framing.amqp_8_0.MethodDispatcher_8_0;
-import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager;
-
-public class ServerMethodDispatcherImpl_8_0
- extends ServerMethodDispatcherImpl
- implements MethodDispatcher_8_0
-{
- public ServerMethodDispatcherImpl_8_0(AMQStateManager stateManager)
- {
- super(stateManager);
- }
-
- public boolean dispatchBasicRecoverOk(BasicRecoverOkBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchChannelAlert(ChannelAlertBody body, int channelId) throws AMQException
- {
- throw new UnexpectedMethodException(body);
- }
-
- public boolean dispatchTestContent(TestContentBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchTestContentOk(TestContentOkBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchTestInteger(TestIntegerBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchTestIntegerOk(TestIntegerOkBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchTestString(TestStringBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchTestStringOk(TestStringOkBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchTestTable(TestTableBody body, int channelId) throws AMQException
- {
- return false;
- }
-
- public boolean dispatchTestTableOk(TestTableOkBody body, int channelId) throws AMQException
- {
- return false;
- }
-}
diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/TxCommitHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/TxCommitHandler.java deleted file mode 100644 index b257030a59..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/TxCommitHandler.java +++ /dev/null @@ -1,85 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.TxCommitBody; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class TxCommitHandler implements StateAwareMethodListener<TxCommitBody> -{ - private static final Logger _log = Logger.getLogger(TxCommitHandler.class); - - private static TxCommitHandler _instance = new TxCommitHandler(); - - public static TxCommitHandler getInstance() - { - return _instance; - } - - private TxCommitHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, TxCommitBody body, final int channelId) throws AMQException - { - final AMQProtocolSession session = stateManager.getProtocolSession(); - - try - { - if (_log.isDebugEnabled()) - { - _log.debug("Commit received on channel " + channelId); - } - AMQChannel channel = session.getChannel(channelId); - - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - channel.commit(new Runnable() - { - - @Override - public void run() - { - MethodRegistry methodRegistry = session.getMethodRegistry(); - AMQMethodBody responseBody = methodRegistry.createTxCommitOkBody(); - session.writeFrame(responseBody.generateFrame(channelId)); - } - }, true); - - - - } - catch (AMQException e) - { - throw body.getChannelException(e.getErrorCode(), "Failed to commit: " + e.getMessage()); - } - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/TxRollbackHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/TxRollbackHandler.java deleted file mode 100644 index 69ad1a0a21..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/TxRollbackHandler.java +++ /dev/null @@ -1,85 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.TxRollbackBody; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class TxRollbackHandler implements StateAwareMethodListener<TxRollbackBody> -{ - private static TxRollbackHandler _instance = new TxRollbackHandler(); - - public static TxRollbackHandler getInstance() - { - return _instance; - } - - private TxRollbackHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, TxRollbackBody body, final int channelId) throws AMQException - { - final AMQProtocolSession session = stateManager.getProtocolSession(); - - try - { - AMQChannel channel = session.getChannel(channelId); - - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - - - - final MethodRegistry methodRegistry = session.getMethodRegistry(); - final AMQMethodBody responseBody = methodRegistry.createTxRollbackOkBody(); - - Runnable task = new Runnable() - { - - public void run() - { - session.writeFrame(responseBody.generateFrame(channelId)); - } - }; - - channel.rollback(task); - - //Now resend all the unacknowledged messages back to the original subscribers. - //(Must be done after the TxnRollback-ok response). - // Why, are we not allowed to send messages back to client before the ok method? - channel.resend(); - - } - catch (AMQException e) - { - throw body.getChannelException(e.getErrorCode(), "Failed to rollback: " + e.getMessage()); - } - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/TxSelectHandler.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/TxSelectHandler.java deleted file mode 100644 index a43e1ebdab..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/TxSelectHandler.java +++ /dev/null @@ -1,62 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.handler; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.TxSelectBody; -import org.apache.qpid.framing.TxSelectOkBody; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager; -import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener; - -public class TxSelectHandler implements StateAwareMethodListener<TxSelectBody> -{ - private static TxSelectHandler _instance = new TxSelectHandler(); - - public static TxSelectHandler getInstance() - { - return _instance; - } - - private TxSelectHandler() - { - } - - public void methodReceived(AMQStateManager stateManager, TxSelectBody body, int channelId) throws AMQException - { - AMQProtocolSession session = stateManager.getProtocolSession(); - - AMQChannel channel = session.getChannel(channelId); - - if (channel == null) - { - throw body.getChannelNotFoundException(channelId); - } - - channel.setLocalTransactional(); - - MethodRegistry methodRegistry = session.getMethodRegistry(); - TxSelectOkBody responseBody = methodRegistry.createTxSelectOkBody(); - session.writeFrame(responseBody.generateFrame(channelId)); - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/output/ProtocolOutputConverterRegistry.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/output/ProtocolOutputConverterRegistry.java deleted file mode 100644 index d4332b37ee..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/output/ProtocolOutputConverterRegistry.java +++ /dev/null @@ -1,90 +0,0 @@ -/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
- */
-
-/*
- * This file is auto-generated by Qpid Gentools v.0.1 - do not modify.
- * Supported AMQP versions:
- * 8-0
- */
-package org.apache.qpid.server.protocol.v0_8.output;
-
-import org.apache.qpid.framing.MethodRegistry;
-import org.apache.qpid.framing.ProtocolVersion;
-import org.apache.qpid.server.protocol.v0_8.output.ProtocolOutputConverter.Factory;
-import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession;
-
-import java.util.HashMap;
-import java.util.Map;
-
-public class ProtocolOutputConverterRegistry
-{
-
- private static final Map<ProtocolVersion, Factory> _registry =
- new HashMap<ProtocolVersion, Factory>();
-
-
- static
- {
- register(ProtocolVersion.v8_0);
- register(ProtocolVersion.v0_9);
- register(ProtocolVersion.v0_91);
- }
-
- private ProtocolOutputConverterRegistry()
- {
- }
-
- private static void register(ProtocolVersion version)
- {
-
- _registry.put(version,new ConverterFactory(version));
- }
-
-
- public static ProtocolOutputConverter getConverter(AMQProtocolSession session)
- {
- return _registry.get(session.getProtocolVersion()).newInstance(session);
- }
-
- private static class ConverterFactory implements Factory
- {
- private ProtocolVersion _protocolVersion;
- private MethodRegistry _methodRegistry;
- private int _classId;
-
- public ConverterFactory(ProtocolVersion pv)
- {
- _protocolVersion = pv;
-
- }
-
- public synchronized ProtocolOutputConverter newInstance(AMQProtocolSession session)
- {
- if(_methodRegistry == null)
- {
-
- _methodRegistry = MethodRegistry.getMethodRegistry(_protocolVersion);
-
- }
- return new ProtocolOutputConverterImpl(session, _methodRegistry);
- }
- }
-}
diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/AMQState.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/AMQState.java deleted file mode 100644 index ee97d5fa87..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/AMQState.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.state; - -/** - * States used in the AMQ protocol. Used by the finite state machine to determine - * valid responses. - */ -public enum AMQState -{ - CONNECTION_NOT_STARTED, - CONNECTION_NOT_AUTH, - CONNECTION_NOT_TUNED, - CONNECTION_NOT_OPENED, - CONNECTION_OPEN, - CONNECTION_CLOSING, - CONNECTION_CLOSED -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/AMQStateManager.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/AMQStateManager.java deleted file mode 100644 index 3c1f1dedc3..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/AMQStateManager.java +++ /dev/null @@ -1,153 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.state; - -import java.security.PrivilegedActionException; -import java.security.PrivilegedExceptionAction; - -import javax.security.auth.Subject; - -import org.apache.log4j.Logger; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.ChannelCloseBody; -import org.apache.qpid.framing.ChannelCloseOkBody; -import org.apache.qpid.framing.ChannelOpenBody; -import org.apache.qpid.framing.MethodDispatcher; -import org.apache.qpid.protocol.AMQConstant; -import org.apache.qpid.protocol.AMQMethodEvent; -import org.apache.qpid.protocol.AMQMethodListener; -import org.apache.qpid.server.model.Broker; -import org.apache.qpid.server.protocol.v0_8.AMQChannel; -import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession; -import org.apache.qpid.server.security.SubjectCreator; -import org.apache.qpid.server.util.ServerScopedRuntimeException; - -/** - * The state manager is responsible for managing the state of the protocol session. - * <p> - * For each AMQProtocolHandler there is a separate state manager. - */ -public class AMQStateManager implements AMQMethodListener -{ - private static final Logger _logger = Logger.getLogger(AMQStateManager.class); - - private final Broker<?> _broker; - private final AMQProtocolSession _protocolSession; - /** The current state */ - private AMQState _currentState; - - public AMQStateManager(Broker<?> broker, AMQProtocolSession protocolSession) - { - _broker = broker; - _protocolSession = protocolSession; - _currentState = AMQState.CONNECTION_NOT_STARTED; - - } - - /** - * Get the Broker instance - * - * @return the Broker - */ - public Broker<?> getBroker() - { - return _broker; - } - - public void changeState(AMQState newState) - { - _logger.debug("State changing to " + newState + " from old state " + _currentState); - final AMQState oldState = _currentState; - _currentState = newState; - - } - - public void error(Exception e) - { - _logger.error("State manager received error notification[Current State:" + _currentState + "]: " + e, e); - } - - public <B extends AMQMethodBody> boolean methodReceived(AMQMethodEvent<B> evt) throws AMQException - { - final MethodDispatcher dispatcher = _protocolSession.getMethodDispatcher(); - - final int channelId = evt.getChannelId(); - final B body = evt.getMethod(); - - final AMQChannel channel = _protocolSession.getChannel(channelId); - if(channelId != 0 && channel == null) - { - - if(! ((body instanceof ChannelOpenBody) - || (body instanceof ChannelCloseOkBody) - || (body instanceof ChannelCloseBody))) - { - throw body.getConnectionException(AMQConstant.CHANNEL_ERROR, "channel is closed won't process:" + body); - } - - } - if(channel == null) - { - return body.execute(dispatcher, channelId); - } - else - { - try - { - return Subject.doAs(channel.getSubject(), new PrivilegedExceptionAction<Boolean>() - { - @Override - public Boolean run() throws AMQException - { - return body.execute(dispatcher, channelId); - } - }); - } - catch (PrivilegedActionException e) - { - if(e.getCause() instanceof AMQException) - { - throw (AMQException) e.getCause(); - } - else - { - throw new ServerScopedRuntimeException(e.getCause()); - } - } - - - } - - } - - public AMQProtocolSession getProtocolSession() - { - return _protocolSession; - } - - - public SubjectCreator getSubjectCreator() - { - return _broker.getSubjectCreator(getProtocolSession().getLocalAddress(), getProtocolSession().getTransport().isSecure()); - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/StateAwareMethodListener.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/StateAwareMethodListener.java deleted file mode 100644 index 63ab23919d..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/StateAwareMethodListener.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.state; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQMethodBody; - -/** - * A frame listener that is informed of the protocol state when invoked and has - * the opportunity to update state. - * - */ -public interface StateAwareMethodListener<B extends AMQMethodBody> -{ - void methodReceived(AMQStateManager stateManager, B evt, int channelId) throws AMQException; -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/StateListener.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/StateListener.java deleted file mode 100644 index e065ae0d42..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/StateListener.java +++ /dev/null @@ -1,30 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8.state; - -import org.apache.qpid.AMQException; - -public interface StateListener -{ - void stateChanged(AMQState oldState, AMQState newState) throws AMQException; - - void error(Throwable t); -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AMQChannelTest.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AMQChannelTest.java index 21680ff4e4..2c710bcf9f 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AMQChannelTest.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AMQChannelTest.java @@ -29,7 +29,7 @@ import java.util.Map; import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.BasicContentHeaderProperties; import org.apache.qpid.framing.ContentHeaderBody; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.configuration.BrokerProperties; import org.apache.qpid.server.exchange.ExchangeImpl; import org.apache.qpid.server.message.MessageContentSource; @@ -41,7 +41,7 @@ import org.apache.qpid.test.utils.QpidTestCase; public class AMQChannelTest extends QpidTestCase { private VirtualHostImpl _virtualHost; - private AMQProtocolSession _protocolSession; + private AMQProtocolEngine _protocolSession; private Map<Integer,String> _replies; private Broker _broker; @@ -98,18 +98,17 @@ public class AMQChannelTest extends QpidTestCase AMQChannel channel = new AMQChannel(_protocolSession, 1, _virtualHost.getMessageStore()); channel.setLocalTransactional(); - MessagePublishInfo info = mock(MessagePublishInfo.class); + MessagePublishInfo info = new MessagePublishInfo(new AMQShortString("test"), false, false, null); ExchangeImpl e = mock(ExchangeImpl.class); ContentHeaderBody contentHeaderBody= mock(ContentHeaderBody.class); BasicContentHeaderProperties properties = mock(BasicContentHeaderProperties.class); when(contentHeaderBody.getProperties()).thenReturn(properties); - when(info.getExchange()).thenReturn(new AMQShortString("test")); when(properties.getUserId()).thenReturn(new AMQShortString(_protocolSession.getAuthorizedPrincipal().getName() + "_incorrect")); channel.setPublishFrame(info, e); channel.publishContentHeader(contentHeaderBody); - channel.commit(); + channel.commit(null, false); assertEquals("Unexpected number of replies", 1, _replies.size()); assertEquals("Message authorization passed", "Access Refused", _replies.get(403)); @@ -121,18 +120,17 @@ public class AMQChannelTest extends QpidTestCase AMQChannel channel = new AMQChannel(_protocolSession, 1, _virtualHost.getMessageStore()); channel.setLocalTransactional(); - MessagePublishInfo info = mock(MessagePublishInfo.class); + MessagePublishInfo info = new MessagePublishInfo(new AMQShortString("test"), false, false, null); ExchangeImpl e = mock(ExchangeImpl.class); ContentHeaderBody contentHeaderBody= mock(ContentHeaderBody.class); BasicContentHeaderProperties properties = mock(BasicContentHeaderProperties.class); when(contentHeaderBody.getProperties()).thenReturn(properties); - when(info.getExchange()).thenReturn(new AMQShortString("test")); when(properties.getUserId()).thenReturn(new AMQShortString(_protocolSession.getAuthorizedPrincipal().getName())); channel.setPublishFrame(info, e); channel.publishContentHeader(contentHeaderBody); - channel.commit(); + channel.commit(null, false); assertEquals("Unexpected number of replies", 0, _replies.size()); } diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AckTest.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AckTest.java index 47456f2675..9326f16703 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AckTest.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AckTest.java @@ -29,7 +29,7 @@ import org.apache.qpid.AMQException; import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.BasicContentHeaderProperties; import org.apache.qpid.framing.ContentHeaderBody; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.consumer.ConsumerImpl; import org.apache.qpid.server.flow.LimitlessCreditManager; import org.apache.qpid.server.flow.Pre0_10CreditManager; @@ -51,7 +51,7 @@ public class AckTest extends QpidTestCase private ConsumerTarget_0_8 _subscriptionTarget; private ConsumerImpl _consumer; - private AMQProtocolSession _protocolSession; + private AMQProtocolEngine _protocolEngine; private TestMemoryMessageStore _messageStore; @@ -68,8 +68,8 @@ public class AckTest extends QpidTestCase super.setUp(); BrokerTestHelper.setUp(); _channel = BrokerTestHelper_0_8.createChannel(5); - _protocolSession = _channel.getProtocolSession(); - _virtualHost = _protocolSession.getVirtualHost(); + _protocolEngine = _channel.getConnection(); + _virtualHost = _protocolEngine.getVirtualHost(); _queue = BrokerTestHelper.createQueue(getTestName(), _virtualHost); _messageStore = (TestMemoryMessageStore)_virtualHost.getMessageStore(); } @@ -90,37 +90,10 @@ public class AckTest extends QpidTestCase { for (int i = 1; i <= count; i++) { - MessagePublishInfo publishBody = new MessagePublishInfo() - { - - public AMQShortString getExchange() - { - return new AMQShortString("someExchange"); - } - - public void setExchange(AMQShortString exchange) - { - //To change body of implemented methods use File | Settings | File Templates. - } - - public boolean isImmediate() - { - return false; - } - - public boolean isMandatory() - { - return false; - } - - public AMQShortString getRoutingKey() - { - return new AMQShortString("rk"); - } - }; + MessagePublishInfo publishBody = new MessagePublishInfo(new AMQShortString("someExchange"), false, false, + new AMQShortString("rk")); BasicContentHeaderProperties b = new BasicContentHeaderProperties(); - ContentHeaderBody cb = new ContentHeaderBody(); - cb.setProperties(b); + ContentHeaderBody cb = new ContentHeaderBody(b); if (persistent) { diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AcknowledgeTest.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AcknowledgeTest.java index 235d263798..dcdac07eae 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AcknowledgeTest.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/AcknowledgeTest.java @@ -25,6 +25,7 @@ import java.util.List; import org.apache.qpid.exchange.ExchangeDefaults; import org.apache.qpid.framing.AMQShortString; +import org.apache.qpid.server.message.MessageSource; import org.apache.qpid.server.queue.AMQQueue; import org.apache.qpid.server.store.MessageCounter; import org.apache.qpid.server.store.MessageStore; @@ -75,7 +76,7 @@ public class AcknowledgeTest extends QpidTestCase private InternalTestProtocolSession getSession() { - return (InternalTestProtocolSession)_channel.getProtocolSession(); + return (InternalTestProtocolSession)_channel.getConnection(); } private AMQQueue getQueue() @@ -129,7 +130,7 @@ public class AcknowledgeTest extends QpidTestCase if (getChannel().isTransactional()) { - getChannel().commit(); + getChannel().commit(null, false); } //Ensure they are stored @@ -140,7 +141,7 @@ public class AcknowledgeTest extends QpidTestCase //Subscribe to the queue AMQShortString subscriber = _channel.consumeFromSource(null, - Collections.singleton(_queue), + Collections.<MessageSource>singleton(_queue), true, null, true, false); getQueue().deliverAsync(); @@ -164,7 +165,7 @@ public class AcknowledgeTest extends QpidTestCase if (getChannel().isTransactional()) { - getChannel().commit(); + getChannel().commit(null, false); } // Check Remaining Acknowledgements diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/BrokerTestHelper_0_8.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/BrokerTestHelper_0_8.java index 8b80504d6e..d4c10c50c1 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/BrokerTestHelper_0_8.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/BrokerTestHelper_0_8.java @@ -24,18 +24,15 @@ import org.apache.qpid.AMQException; import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.BasicContentHeaderProperties; import org.apache.qpid.framing.ContentHeaderBody; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.message.MessageDestination; import org.apache.qpid.server.util.BrokerTestHelper; import org.apache.qpid.server.virtualhost.VirtualHostImpl; -import static org.mockito.Mockito.mock; -import static org.mockito.Mockito.when; - public class BrokerTestHelper_0_8 extends BrokerTestHelper { - public static AMQChannel createChannel(int channelId, AMQProtocolSession session) throws AMQException + public static AMQChannel createChannel(int channelId, AMQProtocolEngine session) throws AMQException { AMQChannel channel = new AMQChannel(session, channelId, session.getVirtualHost().getMessageStore()); session.addChannel(channel); @@ -69,9 +66,7 @@ public class BrokerTestHelper_0_8 extends BrokerTestHelper { AMQShortString routingKey = new AMQShortString(queueName); AMQShortString exchangeNameAsShortString = new AMQShortString(exchangeName); - MessagePublishInfo info = mock(MessagePublishInfo.class); - when(info.getExchange()).thenReturn(exchangeNameAsShortString); - when(info.getRoutingKey()).thenReturn(routingKey); + MessagePublishInfo info = new MessagePublishInfo(exchangeNameAsShortString, false, false, routingKey); MessageDestination destination; if(exchangeName == null || "".equals(exchangeName)) @@ -86,22 +81,20 @@ public class BrokerTestHelper_0_8 extends BrokerTestHelper { channel.setPublishFrame(info, destination); - // Set the body size - ContentHeaderBody _headerBody = new ContentHeaderBody(); - _headerBody.setBodySize(0); // Set Minimum properties BasicContentHeaderProperties properties = new BasicContentHeaderProperties(); + properties.setExpiration(0L); properties.setTimestamp(System.currentTimeMillis()); // Make Message Persistent properties.setDeliveryMode((byte) 2); - _headerBody.setProperties(properties); + ContentHeaderBody headerBody = new ContentHeaderBody(properties, 0); - channel.publishContentHeader(_headerBody); + channel.publishContentHeader(headerBody); } channel.sync(); } diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/InternalTestProtocolSession.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/InternalTestProtocolSession.java index 05ae5285ad..895c8e687c 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/InternalTestProtocolSession.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/InternalTestProtocolSession.java @@ -39,14 +39,13 @@ import org.apache.log4j.Logger; import org.apache.qpid.AMQException; import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.ContentHeaderBody; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.protocol.AMQConstant; import org.apache.qpid.server.consumer.ConsumerImpl; import org.apache.qpid.server.message.InstanceProperties; import org.apache.qpid.server.message.MessageContentSource; import org.apache.qpid.server.message.ServerMessage; import org.apache.qpid.server.model.Broker; -import org.apache.qpid.server.protocol.v0_8.output.ProtocolOutputConverter; import org.apache.qpid.server.security.auth.AuthenticatedPrincipal; import org.apache.qpid.server.security.auth.UsernamePrincipal; import org.apache.qpid.server.virtualhost.VirtualHostImpl; @@ -231,7 +230,7 @@ public class InternalTestProtocolSession extends AMQProtocolEngine implements Pr //Simulate the Client responding with a CloseOK // should really update the StateManger but we don't have access here // changeState(AMQState.CONNECTION_CLOSED); - ((AMQChannel)session).getProtocolSession().closeSession(); + ((AMQChannel)session).getConnection().closeSession(); } diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MaxChannelsTest.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MaxChannelsTest.java index 16c890eaea..107e64bee5 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MaxChannelsTest.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MaxChannelsTest.java @@ -20,8 +20,6 @@ */ package org.apache.qpid.server.protocol.v0_8; -import org.apache.qpid.AMQException; -import org.apache.qpid.protocol.AMQConstant; import org.apache.qpid.server.util.BrokerTestHelper; import org.apache.qpid.test.utils.QpidTestCase; @@ -46,23 +44,16 @@ public class MaxChannelsTest extends QpidTestCase long maxChannels = 10L; _session.setMaximumNumberOfChannels(maxChannels); - assertEquals("Number of channels not correctly set.", new Long(maxChannels), _session.getMaximumNumberOfChannels()); + assertEquals("Number of channels not correctly set.", maxChannels, _session.getMaximumNumberOfChannels()); - for (long currentChannel = 0L; currentChannel < maxChannels; currentChannel++) + for (long currentChannel = 1L; currentChannel <= maxChannels; currentChannel++) { - _session.addChannel(new AMQChannel(_session, (int) currentChannel, null)); + _session.receiveChannelOpen( (int) currentChannel); } - - try - { - _session.addChannel(new AMQChannel(_session, (int) maxChannels, null)); - fail("Cannot create more channels then maximum"); - } - catch (AMQException e) - { - assertEquals("Wrong exception received.", e.getErrorCode(), AMQConstant.NOT_ALLOWED); - } - assertEquals("Maximum number of channels not set.", new Long(maxChannels), new Long(_session.getChannels().size())); + assertFalse("Connection should not be closed after opening " + maxChannels + " channels",_session.isClosed()); + assertEquals("Maximum number of channels not set.", maxChannels, _session.getChannels().size()); + _session.receiveChannelOpen((int) maxChannels+1); + assertTrue("Connection should be closed after opening " + (maxChannels + 1) + " channels",_session.isClosed()); } @Override diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MockMessagePublishInfo.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MockMessagePublishInfo.java deleted file mode 100644 index ab29e58a6c..0000000000 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MockMessagePublishInfo.java +++ /dev/null @@ -1,52 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.server.protocol.v0_8; - -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; - -public class MockMessagePublishInfo implements MessagePublishInfo -{ - public AMQShortString getExchange() - { - return null; //To change body of implemented methods use File | Settings | File Templates. - } - - public void setExchange(AMQShortString exchange) - { - //To change body of implemented methods use File | Settings | File Templates. - } - - public boolean isImmediate() - { - return false; //To change body of implemented methods use File | Settings | File Templates. - } - - public boolean isMandatory() - { - return false; //To change body of implemented methods use File | Settings | File Templates. - } - - public AMQShortString getRoutingKey() - { - return null; //To change body of implemented methods use File | Settings | File Templates. - } -} diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MockStoredMessage.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MockStoredMessage.java index 9689976e6f..f21bf07fae 100755 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MockStoredMessage.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/MockStoredMessage.java @@ -25,7 +25,7 @@ import java.nio.ByteBuffer; import org.apache.qpid.framing.BasicContentHeaderProperties; import org.apache.qpid.framing.ContentHeaderBody; import org.apache.qpid.framing.FieldTable; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.store.StoredMessage; public class MockStoredMessage implements StoredMessage<MessageMetaData> @@ -41,7 +41,7 @@ public class MockStoredMessage implements StoredMessage<MessageMetaData> public MockStoredMessage(long messageId, String headerName, Object headerValue) { - this(messageId, new MockMessagePublishInfo(), new ContentHeaderBody(new BasicContentHeaderProperties(), 60), headerName, headerValue); + this(messageId, new MessagePublishInfo(null, false, false, null), new ContentHeaderBody(new BasicContentHeaderProperties()), headerName, headerValue); } public MockStoredMessage(long messageId, MessagePublishInfo info, ContentHeaderBody chb) diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/QueueBrowserUsesNoAckTest.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/QueueBrowserUsesNoAckTest.java index a4402efc84..816485c42b 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/QueueBrowserUsesNoAckTest.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/QueueBrowserUsesNoAckTest.java @@ -27,6 +27,7 @@ import org.apache.qpid.common.AMQPFilterTypes; import org.apache.qpid.exchange.ExchangeDefaults; import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.FieldTable; +import org.apache.qpid.server.message.MessageSource; import org.apache.qpid.server.queue.AMQQueue; import org.apache.qpid.server.store.MessageCounter; import org.apache.qpid.server.store.MessageStore; @@ -77,7 +78,7 @@ public class QueueBrowserUsesNoAckTest extends QpidTestCase private InternalTestProtocolSession getSession() { - return (InternalTestProtocolSession)_channel.getProtocolSession(); + return (InternalTestProtocolSession)_channel.getConnection(); } private AMQQueue getQueue() @@ -144,6 +145,6 @@ public class QueueBrowserUsesNoAckTest extends QpidTestCase FieldTable filters = new FieldTable(); filters.put(AMQPFilterTypes.NO_CONSUME.getValue(), true); - return channel.consumeFromSource(null, Collections.singleton(queue), true, filters, true, false); + return channel.consumeFromSource(null, Collections.<MessageSource>singleton(queue), true, filters, true, false); } } diff --git a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/ReferenceCountingTest.java b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/ReferenceCountingTest.java index e0f0fc98a5..6059f7f4e5 100644 --- a/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/ReferenceCountingTest.java +++ b/qpid/java/broker-plugins/amqp-0-8-protocol/src/test/java/org/apache/qpid/server/protocol/v0_8/ReferenceCountingTest.java @@ -23,10 +23,9 @@ package org.apache.qpid.server.protocol.v0_8; import java.util.UUID; import org.apache.qpid.AMQException; -import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.BasicContentHeaderProperties; import org.apache.qpid.framing.ContentHeaderBody; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.message.EnqueueableMessage; import org.apache.qpid.server.message.MessageReference; import org.apache.qpid.server.store.MessageCounter; @@ -57,36 +56,7 @@ public class ReferenceCountingTest extends QpidTestCase { ContentHeaderBody chb = createPersistentContentHeader(); - MessagePublishInfo info = new MessagePublishInfo() - { - - public AMQShortString getExchange() - { - return null; - } - - public void setExchange(AMQShortString exchange) - { - //To change body of implemented methods use File | Settings | File Templates. - } - - public boolean isImmediate() - { - return false; - } - - public boolean isMandatory() - { - return false; - } - - public AMQShortString getRoutingKey() - { - return null; - } - }; - - + MessagePublishInfo info = new MessagePublishInfo(null, false, false, null); final MessageMetaData mmd = new MessageMetaData(info, chb); @@ -114,44 +84,16 @@ public class ReferenceCountingTest extends QpidTestCase private ContentHeaderBody createPersistentContentHeader() { - ContentHeaderBody chb = new ContentHeaderBody(); BasicContentHeaderProperties bchp = new BasicContentHeaderProperties(); bchp.setDeliveryMode((byte)2); - chb.setProperties(bchp); + ContentHeaderBody chb = new ContentHeaderBody(bchp); return chb; } public void testMessageRemains() throws AMQException { - MessagePublishInfo info = new MessagePublishInfo() - { - - public AMQShortString getExchange() - { - return null; - } - - public void setExchange(AMQShortString exchange) - { - //To change body of implemented methods use File | Settings | File Templates. - } - - public boolean isImmediate() - { - return false; - } - - public boolean isMandatory() - { - return false; - } - - public AMQShortString getRoutingKey() - { - return null; - } - }; + MessagePublishInfo info = new MessagePublishInfo(null, false, false, null); final ContentHeaderBody chb = createPersistentContentHeader(); diff --git a/qpid/java/broker-plugins/amqp-msg-conv-0-8-to-0-10/src/main/java/org/apache/qpid/server/protocol/converter/v0_8_v0_10/MessageConverter_0_10_to_0_8.java b/qpid/java/broker-plugins/amqp-msg-conv-0-8-to-0-10/src/main/java/org/apache/qpid/server/protocol/converter/v0_8_v0_10/MessageConverter_0_10_to_0_8.java index d3c1dae29b..02c3373f85 100644 --- a/qpid/java/broker-plugins/amqp-msg-conv-0-8-to-0-10/src/main/java/org/apache/qpid/server/protocol/converter/v0_8_v0_10/MessageConverter_0_10_to_0_8.java +++ b/qpid/java/broker-plugins/amqp-msg-conv-0-8-to-0-10/src/main/java/org/apache/qpid/server/protocol/converter/v0_8_v0_10/MessageConverter_0_10_to_0_8.java @@ -30,7 +30,7 @@ import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.BasicContentHeaderProperties; import org.apache.qpid.framing.ContentHeaderBody; import org.apache.qpid.framing.FieldTable; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.exchange.ExchangeImpl; import org.apache.qpid.server.plugin.MessageConverter; import org.apache.qpid.server.plugin.PluggableService; @@ -239,7 +239,7 @@ public class MessageConverter_0_10_to_0_8 implements MessageConverter<MessageTra private ContentHeaderBody convertContentHeaderBody(MessageTransferMessage message, VirtualHostImpl vhost) { BasicContentHeaderProperties props = convertContentHeaderProperties(message, vhost); - ContentHeaderBody chb = new ContentHeaderBody(props, BASIC_CLASS_ID); + ContentHeaderBody chb = new ContentHeaderBody(props); chb.setBodySize(message.getSize()); return chb; } @@ -256,38 +256,7 @@ public class MessageConverter_0_10_to_0_8 implements MessageConverter<MessageTra final boolean immediate = delvProps != null && delvProps.getImmediate(); final boolean mandatory = delvProps != null && !delvProps.getDiscardUnroutable(); - return new MessagePublishInfo() - { - @Override - public AMQShortString getExchange() - { - return exchangeName; - } - - @Override - public void setExchange(AMQShortString exchange) - { - throw new UnsupportedOperationException(); - } - - @Override - public boolean isImmediate() - { - return immediate; - } - - @Override - public boolean isMandatory() - { - return mandatory; - } - - @Override - public AMQShortString getRoutingKey() - { - return routingKey; - } - }; + return new MessagePublishInfo(exchangeName, immediate, mandatory, routingKey); } @Override diff --git a/qpid/java/broker-plugins/amqp-msg-conv-0-8-to-1-0/src/main/java/org/apache/qpid/server/protocol/converter/v0_8_v1_0/MessageConverter_1_0_to_v0_8.java b/qpid/java/broker-plugins/amqp-msg-conv-0-8-to-1-0/src/main/java/org/apache/qpid/server/protocol/converter/v0_8_v1_0/MessageConverter_1_0_to_v0_8.java index 783c6ca772..647e6be28a 100644 --- a/qpid/java/broker-plugins/amqp-msg-conv-0-8-to-1-0/src/main/java/org/apache/qpid/server/protocol/converter/v0_8_v1_0/MessageConverter_1_0_to_v0_8.java +++ b/qpid/java/broker-plugins/amqp-msg-conv-0-8-to-1-0/src/main/java/org/apache/qpid/server/protocol/converter/v0_8_v1_0/MessageConverter_1_0_to_v0_8.java @@ -28,7 +28,7 @@ import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.BasicContentHeaderProperties; import org.apache.qpid.framing.ContentHeaderBody; import org.apache.qpid.framing.FieldTable; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.plugin.MessageConverter; import org.apache.qpid.server.plugin.PluggableService; import org.apache.qpid.server.protocol.v0_8.AMQMessage; @@ -137,45 +137,13 @@ public class MessageConverter_1_0_to_v0_8 implements MessageConverter<Message_1_ { final MessageMetaData_1_0.MessageHeader_1_0 header = serverMsg.getMessageHeader(); + String key = header.getTo(); + if(key == null) + { + key = header.getSubject(); + } - MessagePublishInfo publishInfo = new MessagePublishInfo() - { - @Override - public AMQShortString getExchange() - { - return null; - } - - @Override - public void setExchange(final AMQShortString amqShortString) - { - throw new UnsupportedOperationException(); - } - - @Override - public boolean isImmediate() - { - return false; - } - - @Override - public boolean isMandatory() - { - return false; - } - - @Override - public AMQShortString getRoutingKey() - { - String key = header.getTo(); - if(key == null) - { - key = header.getSubject(); - } - - return AMQShortString.valueOf(key); - } - }; + MessagePublishInfo publishInfo = new MessagePublishInfo(null, false, false, AMQShortString.valueOf(key)); final BasicContentHeaderProperties props = new BasicContentHeaderProperties(); @@ -204,7 +172,7 @@ public class MessageConverter_1_0_to_v0_8 implements MessageConverter<Message_1_ props.setHeaders(FieldTable.convertToFieldTable(headerProps)); - final ContentHeaderBody chb = new ContentHeaderBody(props, BASIC_CLASS_ID); + final ContentHeaderBody chb = new ContentHeaderBody(props); chb.setBodySize(size); return new MessageMetaData(publishInfo, chb, serverMsg.getArrivalTime()); diff --git a/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSession_0_8.java b/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSession_0_8.java index 77225a948d..d86a2739f2 100644 --- a/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSession_0_8.java +++ b/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSession_0_8.java @@ -62,8 +62,6 @@ import org.apache.qpid.client.state.listener.SpecificMethodFrameListener; import org.apache.qpid.common.AMQPFilterTypes; import org.apache.qpid.configuration.ClientProperties; import org.apache.qpid.framing.*; -import org.apache.qpid.framing.amqp_0_9.MethodRegistry_0_9; -import org.apache.qpid.framing.amqp_0_91.MethodRegistry_0_91; import org.apache.qpid.jms.Session; import org.apache.qpid.protocol.AMQConstant; import org.apache.qpid.protocol.AMQMethodEvent; @@ -316,21 +314,12 @@ public class AMQSession_0_8 extends AMQSession<BasicMessageConsumer_0_8, BasicMe if(getProtocolHandler().getProtocolVersion().equals(ProtocolVersion.v8_0)) { BasicRecoverBody body = getMethodRegistry().createBasicRecoverBody(false); - getAMQConnection().getProtocolHandler().syncWrite(body.generateFrame(getChannelId()), BasicRecoverOkBody.class); - } - else if(getProtocolVersion().equals(ProtocolVersion.v0_9)) - { - BasicRecoverSyncBody body = ((MethodRegistry_0_9)getMethodRegistry()).createBasicRecoverSyncBody(false); - getAMQConnection().getProtocolHandler().syncWrite(body.generateFrame(getChannelId()), BasicRecoverSyncOkBody.class); - } - else if(getProtocolVersion().equals(ProtocolVersion.v0_91)) - { - BasicRecoverSyncBody body = ((MethodRegistry_0_91)getMethodRegistry()).createBasicRecoverSyncBody(false); getAMQConnection().getProtocolHandler().syncWrite(body.generateFrame(getChannelId()), BasicRecoverSyncOkBody.class); } else { - throw new RuntimeException("Unsupported version of the AMQP Protocol: " + getProtocolVersion()); + BasicRecoverSyncBody body = getMethodRegistry().createBasicRecoverSyncBody(false); + getAMQConnection().getProtocolHandler().syncWrite(body.generateFrame(getChannelId()), BasicRecoverSyncOkBody.class); } } } @@ -1148,33 +1137,22 @@ public class AMQSession_0_8 extends AMQSession<BasicMessageConsumer_0_8, BasicMe if (isBound(null, AMQShortString.valueOf(queue), null)) { - MethodRegistry methodRegistry = getProtocolHandler().getMethodRegistry(); - AMQMethodBody body; - if (methodRegistry instanceof MethodRegistry_0_9) + + if(ProtocolVersion.v8_0.equals(getProtocolVersion())) { - String bindingKey = binding.getBindingKey() == null ? queue : binding.getBindingKey(); + throw new AMQException(AMQConstant.NOT_IMPLEMENTED, "Cannot unbind a queue in AMQP 0-8"); + } - MethodRegistry_0_9 methodRegistry_0_9 = (MethodRegistry_0_9) methodRegistry; - body = methodRegistry_0_9.createQueueUnbindBody(getTicket(), + MethodRegistry methodRegistry = getProtocolHandler().getMethodRegistry(); + + String bindingKey = binding.getBindingKey() == null ? queue : binding.getBindingKey(); + + AMQMethodBody body = methodRegistry.createQueueUnbindBody(getTicket(), AMQShortString.valueOf(queue), AMQShortString.valueOf(exchange), AMQShortString.valueOf(bindingKey), null); - } - else if (methodRegistry instanceof MethodRegistry_0_91) - { - MethodRegistry_0_91 methodRegistry_0_91 = (MethodRegistry_0_91) methodRegistry; - body = methodRegistry_0_91.createQueueUnbindBody(getTicket(), - AMQShortString.valueOf(queue), - AMQShortString.valueOf(exchange), - AMQShortString.valueOf(binding.getBindingKey()), - null); - } - else - { - throw new AMQException(AMQConstant.NOT_IMPLEMENTED, "Cannot unbind a queue in AMQP 0-8"); - } getProtocolHandler().syncWrite(body.generateFrame(getChannelId()), QueueUnbindOkBody.class); return null; } diff --git a/qpid/java/client/src/main/java/org/apache/qpid/client/BasicMessageProducer_0_8.java b/qpid/java/client/src/main/java/org/apache/qpid/client/BasicMessageProducer_0_8.java index 4dcd5a2e44..69d02566bf 100644 --- a/qpid/java/client/src/main/java/org/apache/qpid/client/BasicMessageProducer_0_8.java +++ b/qpid/java/client/src/main/java/org/apache/qpid/client/BasicMessageProducer_0_8.java @@ -216,7 +216,7 @@ public class BasicMessageProducer_0_8 extends BasicMessageProducer AMQFrame contentHeaderFrame = ContentHeaderBody.createAMQFrame(getChannelId(), - classIfForBasic, 0, contentHeaderProperties, size); + contentHeaderProperties, size); if(contentHeaderFrame.getSize() > getSession().getAMQConnection().getMaximumFrameSize()) { throw new JMSException("Unable to send message as the headers are too large (" diff --git a/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl.java b/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl.java index d76fdf25e6..e6eb2d814f 100644 --- a/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl.java +++ b/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl.java @@ -125,6 +125,28 @@ public class ClientMethodDispatcherImpl implements MethodDispatcher return false; } + @Override + public boolean dispatchQueueUnbindOk(final QueueUnbindOkBody body, final int channelId) + throws AMQException + { + throw new AMQMethodNotImplementedException(body); + } + + @Override + public boolean dispatchBasicRecoverSyncOk(final BasicRecoverSyncOkBody basicRecoverSyncOkBody, + final int channelId) + throws AMQException + { + return false; + } + + @Override + public boolean dispatchChannelAlert(final ChannelAlertBody channelAlertBody, final int channelId) + throws AMQException + { + return false; + } + public boolean dispatchBasicCancelOk(BasicCancelOkBody body, int channelId) throws AMQException { _basicCancelOkMethodHandler.methodReceived(_session, body, channelId); @@ -244,16 +266,6 @@ public class ClientMethodDispatcherImpl implements MethodDispatcher return false; } - public boolean dispatchStreamCancelOk(StreamCancelOkBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchStreamConsumeOk(StreamConsumeOkBody body, int channelId) throws AMQException - { - return false; - } - public boolean dispatchAccessRequest(AccessRequestBody body, int channelId) throws AMQException { throw new AMQMethodNotImplementedException(body); @@ -324,16 +336,6 @@ public class ClientMethodDispatcherImpl implements MethodDispatcher throw new AMQMethodNotImplementedException(body); } - public boolean dispatchDtxSelect(DtxSelectBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchDtxStart(DtxStartBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - public boolean dispatchExchangeBound(ExchangeBoundBody body, int channelId) throws AMQException { throw new AMQMethodNotImplementedException(body); @@ -349,36 +351,6 @@ public class ClientMethodDispatcherImpl implements MethodDispatcher throw new AMQMethodNotImplementedException(body); } - public boolean dispatchFileAck(FileAckBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchFileCancel(FileCancelBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchFileConsume(FileConsumeBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchFilePublish(FilePublishBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchFileQos(FileQosBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchFileReject(FileRejectBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - public boolean dispatchQueueBind(QueueBindBody body, int channelId) throws AMQException { throw new AMQMethodNotImplementedException(body); @@ -399,30 +371,6 @@ public class ClientMethodDispatcherImpl implements MethodDispatcher throw new AMQMethodNotImplementedException(body); } - public boolean dispatchStreamCancel(StreamCancelBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchStreamConsume(StreamConsumeBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchStreamPublish(StreamPublishBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchStreamQos(StreamQosBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchTunnelRequest(TunnelRequestBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } public boolean dispatchTxCommit(TxCommitBody body, int channelId) throws AMQException { @@ -439,14 +387,17 @@ public class ClientMethodDispatcherImpl implements MethodDispatcher throw new AMQMethodNotImplementedException(body); } - public boolean dispatchDtxSelectOk(DtxSelectOkBody body, int channelId) throws AMQException + @Override + public boolean dispatchQueueUnbind(final QueueUnbindBody queueUnbindBody, final int channelId) throws AMQException { - throw new AMQMethodNotImplementedException(body); + return false; } - public boolean dispatchDtxStartOk(DtxStartOkBody body, int channelId) throws AMQException + @Override + public boolean dispatchBasicRecoverSync(final BasicRecoverSyncBody basicRecoverSyncBody, final int channelId) + throws AMQException { - throw new AMQMethodNotImplementedException(body); + return false; } public boolean dispatchExchangeBoundOk(ExchangeBoundOkBody body, int channelId) throws AMQException @@ -465,46 +416,6 @@ public class ClientMethodDispatcherImpl implements MethodDispatcher return false; } - public boolean dispatchFileCancelOk(FileCancelOkBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchFileConsumeOk(FileConsumeOkBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchFileDeliver(FileDeliverBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchFileOpen(FileOpenBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchFileOpenOk(FileOpenOkBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchFileQosOk(FileQosOkBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchFileReturn(FileReturnBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchFileStage(FileStageBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - public boolean dispatchQueueBindOk(QueueBindOkBody body, int channelId) throws AMQException { return false; @@ -515,21 +426,6 @@ public class ClientMethodDispatcherImpl implements MethodDispatcher return false; } - public boolean dispatchStreamDeliver(StreamDeliverBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchStreamQosOk(StreamQosOkBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchStreamReturn(StreamReturnBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - public boolean dispatchTxCommitOk(TxCommitOkBody body, int channelId) throws AMQException { return false; diff --git a/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl_0_9.java b/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl_0_9.java index f4fc3a4715..4232f59292 100644 --- a/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl_0_9.java +++ b/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl_0_9.java @@ -23,10 +23,14 @@ package org.apache.qpid.client.handler; import org.apache.qpid.AMQException; import org.apache.qpid.client.protocol.AMQProtocolSession; import org.apache.qpid.client.state.AMQMethodNotImplementedException; -import org.apache.qpid.framing.*; -import org.apache.qpid.framing.amqp_0_9.MethodDispatcher_0_9; - -public class ClientMethodDispatcherImpl_0_9 extends ClientMethodDispatcherImpl implements MethodDispatcher_0_9 +import org.apache.qpid.framing.BasicRecoverSyncBody; +import org.apache.qpid.framing.BasicRecoverSyncOkBody; +import org.apache.qpid.framing.ChannelAlertBody; +import org.apache.qpid.framing.MethodDispatcher; +import org.apache.qpid.framing.QueueUnbindBody; +import org.apache.qpid.framing.QueueUnbindOkBody; + +public class ClientMethodDispatcherImpl_0_9 extends ClientMethodDispatcherImpl implements MethodDispatcher { public ClientMethodDispatcherImpl_0_9(AMQProtocolSession session) { @@ -38,106 +42,18 @@ public class ClientMethodDispatcherImpl_0_9 extends ClientMethodDispatcherImpl i return false; } - public boolean dispatchBasicRecoverSync(BasicRecoverSyncBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchChannelOk(ChannelOkBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchChannelPing(ChannelPingBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchChannelPong(ChannelPongBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchChannelResume(ChannelResumeBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchMessageAppend(MessageAppendBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageCancel(MessageCancelBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchMessageCheckpoint(MessageCheckpointBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageClose(MessageCloseBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageConsume(MessageConsumeBody body, int channelId) throws AMQException + @Override + public boolean dispatchChannelAlert(final ChannelAlertBody body, final int channelId) + throws AMQException { throw new AMQMethodNotImplementedException(body); } - public boolean dispatchMessageEmpty(MessageEmptyBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageGet(MessageGetBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchMessageOffset(MessageOffsetBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageOk(MessageOkBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageOpen(MessageOpenBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageQos(MessageQosBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchMessageRecover(MessageRecoverBody body, int channelId) throws AMQException + public boolean dispatchBasicRecoverSync(BasicRecoverSyncBody body, int channelId) throws AMQException { throw new AMQMethodNotImplementedException(body); } - public boolean dispatchMessageReject(MessageRejectBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageResume(MessageResumeBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageTransfer(MessageTransferBody body, int channelId) throws AMQException - { - return false; - } - public boolean dispatchQueueUnbind(QueueUnbindBody body, int channelId) throws AMQException { throw new AMQMethodNotImplementedException(body); diff --git a/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl_0_91.java b/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl_0_91.java index 5f33561a8f..573ab52cc3 100644 --- a/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl_0_91.java +++ b/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl_0_91.java @@ -23,10 +23,14 @@ package org.apache.qpid.client.handler; import org.apache.qpid.AMQException; import org.apache.qpid.client.protocol.AMQProtocolSession; import org.apache.qpid.client.state.AMQMethodNotImplementedException; -import org.apache.qpid.framing.*; -import org.apache.qpid.framing.amqp_0_91.MethodDispatcher_0_91; - -public class ClientMethodDispatcherImpl_0_91 extends ClientMethodDispatcherImpl implements MethodDispatcher_0_91 +import org.apache.qpid.framing.BasicRecoverSyncBody; +import org.apache.qpid.framing.BasicRecoverSyncOkBody; +import org.apache.qpid.framing.ChannelAlertBody; +import org.apache.qpid.framing.MethodDispatcher; +import org.apache.qpid.framing.QueueUnbindBody; +import org.apache.qpid.framing.QueueUnbindOkBody; + +public class ClientMethodDispatcherImpl_0_91 extends ClientMethodDispatcherImpl implements MethodDispatcher { public ClientMethodDispatcherImpl_0_91(AMQProtocolSession session) { @@ -38,119 +42,26 @@ public class ClientMethodDispatcherImpl_0_91 extends ClientMethodDispatcherImpl return false; } - public boolean dispatchBasicRecoverSync(BasicRecoverSyncBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchChannelOk(ChannelOkBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchChannelPing(ChannelPingBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchChannelPong(ChannelPongBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchChannelResume(ChannelResumeBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchMessageAppend(MessageAppendBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageCancel(MessageCancelBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchMessageCheckpoint(MessageCheckpointBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageClose(MessageCloseBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageConsume(MessageConsumeBody body, int channelId) throws AMQException + @Override + public boolean dispatchChannelAlert(final ChannelAlertBody body, final int channelId) + throws AMQException { throw new AMQMethodNotImplementedException(body); } - public boolean dispatchMessageEmpty(MessageEmptyBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageGet(MessageGetBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchMessageOffset(MessageOffsetBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageOk(MessageOkBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageOpen(MessageOpenBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageQos(MessageQosBody body, int channelId) throws AMQException - { - throw new AMQMethodNotImplementedException(body); - } - - public boolean dispatchMessageRecover(MessageRecoverBody body, int channelId) throws AMQException + public boolean dispatchBasicRecoverSync(BasicRecoverSyncBody body, int channelId) throws AMQException { throw new AMQMethodNotImplementedException(body); } - public boolean dispatchMessageReject(MessageRejectBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageResume(MessageResumeBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchMessageTransfer(MessageTransferBody body, int channelId) throws AMQException - { - return false; - } - public boolean dispatchQueueUnbind(QueueUnbindBody body, int channelId) throws AMQException { throw new AMQMethodNotImplementedException(body); } - public boolean dispatchBasicRecoverOk(BasicRecoverOkBody body, int channelId) throws AMQException - { - return false; - } - public boolean dispatchQueueUnbindOk(QueueUnbindOkBody body, int channelId) throws AMQException { return false; } -}
\ No newline at end of file +} diff --git a/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl_8_0.java b/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl_8_0.java index 28ad6037d4..7d421622e7 100644 --- a/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl_8_0.java +++ b/qpid/java/client/src/main/java/org/apache/qpid/client/handler/ClientMethodDispatcherImpl_8_0.java @@ -22,72 +22,49 @@ import org.apache.qpid.AMQException; import org.apache.qpid.client.protocol.AMQProtocolSession; -import org.apache.qpid.framing.BasicRecoverOkBody; +import org.apache.qpid.client.state.AMQMethodNotImplementedException; +import org.apache.qpid.framing.BasicRecoverSyncBody; +import org.apache.qpid.framing.BasicRecoverSyncOkBody; import org.apache.qpid.framing.ChannelAlertBody; -import org.apache.qpid.framing.TestContentBody; -import org.apache.qpid.framing.TestContentOkBody; -import org.apache.qpid.framing.TestIntegerBody; -import org.apache.qpid.framing.TestIntegerOkBody; -import org.apache.qpid.framing.TestStringBody; -import org.apache.qpid.framing.TestStringOkBody; -import org.apache.qpid.framing.TestTableBody; -import org.apache.qpid.framing.TestTableOkBody; -import org.apache.qpid.framing.amqp_8_0.MethodDispatcher_8_0; +import org.apache.qpid.framing.MethodDispatcher; +import org.apache.qpid.framing.QueueUnbindBody; +import org.apache.qpid.framing.QueueUnbindOkBody; -public class ClientMethodDispatcherImpl_8_0 extends ClientMethodDispatcherImpl implements MethodDispatcher_8_0 +public class ClientMethodDispatcherImpl_8_0 extends ClientMethodDispatcherImpl implements MethodDispatcher { public ClientMethodDispatcherImpl_8_0(AMQProtocolSession session) { super(session); } - public boolean dispatchBasicRecoverOk(BasicRecoverOkBody body, int channelId) throws AMQException - { - return false; - } - public boolean dispatchChannelAlert(ChannelAlertBody body, int channelId) throws AMQException { return false; } - public boolean dispatchTestContent(TestContentBody body, int channelId) throws AMQException + @Override + public boolean dispatchQueueUnbindOk(final QueueUnbindOkBody queueUnbindOkBody, final int channelId) { return false; } - public boolean dispatchTestContentOk(TestContentOkBody body, int channelId) throws AMQException + @Override + public boolean dispatchBasicRecoverSyncOk(final BasicRecoverSyncOkBody basicRecoverSyncOkBody, + final int channelId) { return false; } - public boolean dispatchTestInteger(TestIntegerBody body, int channelId) throws AMQException + @Override + public boolean dispatchQueueUnbind(final QueueUnbindBody body, final int channelId) throws AMQException { - return false; - } - - public boolean dispatchTestIntegerOk(TestIntegerOkBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchTestString(TestStringBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchTestStringOk(TestStringOkBody body, int channelId) throws AMQException - { - return false; - } - - public boolean dispatchTestTable(TestTableBody body, int channelId) throws AMQException - { - return false; + throw new AMQMethodNotImplementedException(body); } - public boolean dispatchTestTableOk(TestTableOkBody body, int channelId) throws AMQException + @Override + public boolean dispatchBasicRecoverSync(final BasicRecoverSyncBody body, final int channelId) + throws AMQException { - return false; + throw new AMQMethodNotImplementedException(body); } } diff --git a/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolHandler.java b/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolHandler.java index 5c9d8f9b91..bb98c0abbd 100644 --- a/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolHandler.java +++ b/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolHandler.java @@ -23,8 +23,8 @@ package org.apache.qpid.client.protocol; import java.io.IOException; import java.net.SocketAddress; import java.nio.ByteBuffer; -import java.util.ArrayList; import java.util.Iterator; +import java.util.List; import java.util.Set; import java.util.concurrent.CopyOnWriteArraySet; import java.util.concurrent.CountDownLatch; @@ -48,6 +48,7 @@ import org.apache.qpid.client.state.AMQStateManager; import org.apache.qpid.client.state.StateWaiter; import org.apache.qpid.client.state.listener.SpecificMethodFrameListener; import org.apache.qpid.codec.AMQDecoder; +import org.apache.qpid.codec.ClientDecoder; import org.apache.qpid.configuration.ClientProperties; import org.apache.qpid.framing.AMQBody; import org.apache.qpid.framing.AMQDataBlock; @@ -193,7 +194,7 @@ public class AMQProtocolHandler implements ProtocolEngine _connection = con; _protocolSession = new AMQProtocolSession(this, _connection); _stateManager = new AMQStateManager(_protocolSession); - _decoder = new AMQDecoder(false, _protocolSession); + _decoder = new ClientDecoder(_protocolSession.getMethodProcessor()); _failoverHandler = new FailoverHandler(this); } @@ -459,9 +460,10 @@ public class AMQProtocolHandler implements ProtocolEngine { _readBytes += msg.remaining(); _lastReadTime = System.currentTimeMillis(); + final List<AMQDataBlock> dataBlocks = _protocolSession.getMethodProcessor().getProcessedMethods(); try { - final ArrayList<AMQDataBlock> dataBlocks = _decoder.decodeBuffer(msg); + _decoder.decodeBuffer(msg); // Decode buffer int size = dataBlocks.size(); @@ -511,6 +513,10 @@ public class AMQProtocolHandler implements ProtocolEngine propagateExceptionToFrameListeners(e); exception(e); } + finally + { + dataBlocks.clear(); + } } @@ -753,8 +759,12 @@ public class AMQProtocolHandler implements ProtocolEngine // Connection is already closed then don't do a syncWrite try { - final ConnectionCloseBody body = _protocolSession.getMethodRegistry().createConnectionCloseBody(AMQConstant.REPLY_SUCCESS.getCode(), // replyCode - new AMQShortString("JMS client is closing the connection."), 0, 0); + final ConnectionCloseBody body = _protocolSession.getMethodRegistry().createConnectionCloseBody( + AMQConstant.REPLY_SUCCESS.getCode(), + // replyCode + new AMQShortString("JMS client is closing the connection."), + 0, + 0); final AMQFrame frame = body.generateFrame(0); syncWrite(frame, ConnectionCloseOkBody.class, timeout); diff --git a/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolSession.java b/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolSession.java index 2c69aa1b51..2fbb13079e 100644 --- a/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolSession.java +++ b/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolSession.java @@ -44,6 +44,7 @@ import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.ContentBody; import org.apache.qpid.framing.ContentHeaderBody; import org.apache.qpid.framing.FieldTable; +import org.apache.qpid.framing.FrameCreatingMethodProcessor; import org.apache.qpid.framing.HeartbeatBody; import org.apache.qpid.framing.MethodDispatcher; import org.apache.qpid.framing.MethodRegistry; @@ -88,8 +89,11 @@ public class AMQProtocolSession implements AMQVersionAwareProtocolSession private ProtocolVersion _protocolVersion; - private MethodRegistry _methodRegistry = - MethodRegistry.getMethodRegistry(ProtocolVersion.getLatestSupportedVersion()); + private final MethodRegistry _methodRegistry = + new MethodRegistry(ProtocolVersion.getLatestSupportedVersion()); + + private final FrameCreatingMethodProcessor _methodProcessor = + new FrameCreatingMethodProcessor(ProtocolVersion.getLatestSupportedVersion()); private MethodDispatcher _methodDispatcher; @@ -416,7 +420,8 @@ public class AMQProtocolSession implements AMQVersionAwareProtocolSession _logger.debug("Setting ProtocolVersion to :" + pv); } _protocolVersion = pv; - _methodRegistry = MethodRegistry.getMethodRegistry(pv); + _methodRegistry.setProtocolVersion(pv); + _methodProcessor.setProtocolVersion(pv); _methodDispatcher = ClientMethodDispatcherImpl.newMethodDispatcher(pv, this); } @@ -549,4 +554,9 @@ public class AMQProtocolSession implements AMQVersionAwareProtocolSession { _protocolHandler.setMaxFrameSize(frameMax); } + + public FrameCreatingMethodProcessor getMethodProcessor() + { + return _methodProcessor; + } } diff --git a/qpid/java/client/src/test/java/org/apache/qpid/client/AMQSession_0_8Test.java b/qpid/java/client/src/test/java/org/apache/qpid/client/AMQSession_0_8Test.java index c56cf9a72b..2a8ab22b81 100644 --- a/qpid/java/client/src/test/java/org/apache/qpid/client/AMQSession_0_8Test.java +++ b/qpid/java/client/src/test/java/org/apache/qpid/client/AMQSession_0_8Test.java @@ -23,7 +23,7 @@ package org.apache.qpid.client; import org.apache.qpid.AMQException; import org.apache.qpid.client.transport.TestNetworkConnection; import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.amqp_0_91.QueueDeclareOkBodyImpl; +import org.apache.qpid.framing.QueueDeclareOkBody; import org.apache.qpid.test.utils.QpidTestCase; import org.apache.qpid.transport.network.NetworkConnection; import org.apache.qpid.url.AMQBindingURL; @@ -50,7 +50,7 @@ public class AMQSession_0_8Test extends QpidTestCase { try { - _connection.getProtocolHandler().methodBodyReceived(1, new QueueDeclareOkBodyImpl(testQueueName, 0, 0)); + _connection.getProtocolHandler().methodBodyReceived(1, new QueueDeclareOkBody(testQueueName, 0, 0)); } catch (AMQException e) { diff --git a/qpid/java/client/src/test/java/org/apache/qpid/client/protocol/AMQProtocolHandlerTest.java b/qpid/java/client/src/test/java/org/apache/qpid/client/protocol/AMQProtocolHandlerTest.java index 70fcfcedb8..61e5247ead 100644 --- a/qpid/java/client/src/test/java/org/apache/qpid/client/protocol/AMQProtocolHandlerTest.java +++ b/qpid/java/client/src/test/java/org/apache/qpid/client/protocol/AMQProtocolHandlerTest.java @@ -20,6 +20,9 @@ */ package org.apache.qpid.client.protocol; +import java.util.concurrent.CountDownLatch; +import java.util.concurrent.TimeUnit; + import junit.framework.TestCase; import org.slf4j.Logger; import org.slf4j.LoggerFactory; @@ -32,12 +35,10 @@ import org.apache.qpid.client.transport.TestNetworkConnection; import org.apache.qpid.framing.AMQBody; import org.apache.qpid.framing.AMQFrame; import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.amqp_8_0.BasicRecoverOkBodyImpl; +import org.apache.qpid.framing.BasicRecoverSyncOkBody; +import org.apache.qpid.framing.ProtocolVersion; import org.apache.qpid.protocol.AMQConstant; -import java.util.concurrent.CountDownLatch; -import java.util.concurrent.TimeUnit; - /** * This is a test address QPID-1431 where frame listeners would fail to be notified of an incomming exception. * @@ -75,7 +76,7 @@ public class AMQProtocolHandlerTest extends TestCase //Create a new ProtocolHandler with a fake connection. _handler = new AMQProtocolHandler(new MockAMQConnection("amqp://guest:guest@client/test?brokerlist='tcp://localhost:1'")); _handler.setNetworkConnection(new TestNetworkConnection()); - AMQBody body = BasicRecoverOkBodyImpl.getFactory().newInstance(null, 1); + AMQBody body = new BasicRecoverSyncOkBody(ProtocolVersion.v8_0); _blockFrame = new AMQFrame(0, body); _handleCountDown = new CountDownLatch(1); diff --git a/qpid/java/common/build-generate-sources.xml b/qpid/java/common/build-generate-sources.xml index cd88bfecb1..d5a28e3130 100644 --- a/qpid/java/common/build-generate-sources.xml +++ b/qpid/java/common/build-generate-sources.xml @@ -23,11 +23,7 @@ <fail message="A required property was not set"> <condition> <not> - <and> - <isset property="generated-amqp-0-8-dir"/> - <isset property="generated-amqp-0-10-dir"/> - <isset property="gentools.classes"/> - </and> + <isset property="generated-amqp-0-10-dir"/> </not> </condition> </fail> @@ -39,14 +35,8 @@ <property name="mllib.dir" value="${basedir}/../../python"/> <property name="xml.spec.dir" value="${basedir}/../../specs"/> - <property name="xml.spec.0-8" value="amqp0-8-qpid.stripped.xml"/> - <property name="xml.spec.0-9" value="amqp0-9-qpid.stripped.xml"/> - <property name="xml.spec.0-9-1" value="amqp0-9-1.stripped.xml"/> <property name="xml.spec.0-10" value="amqp.0-10-qpid-errata.stripped.xml"/> - <property name="xml.spec.deps.0-8" value="${xml.spec.0-8} ${xml.spec.0-9} ${xml.spec.0-9-1}"/> - <property name="xml.spec.list.0-8" value='"${xml.spec.dir}/${xml.spec.0-8}" "${xml.spec.dir}/${xml.spec.0-9}" "${xml.spec.dir}/${xml.spec.0-9-1}"'/> - <property name="gentools.src" value="${basedir}/gentools/src"/> <property name="generated.package" value="org/apache/qpid/framing" /> @@ -65,27 +55,6 @@ </java> </target> - <target name="compile-gentools"> - <mkdir dir="${gentools.classes}"/> - <javac srcdir="${gentools.src}" destdir="${gentools.classes}" source="${java.source}" target="${java.target}" fork="true" includeantruntime="false"> - <classpath> - <path refid="source.generation.classpathref"/> - </classpath> - </javac> - </target> - - <target name="amqp-0-8-generation" depends="compile-gentools" if="generate.protocol.sources"> - <mkdir dir="${generated-amqp-0-8-dir}/${generated.package}"/> - <echo message="Generating AMQP 0-8/0-9/0-9-1 protocol classes..."/> - <java classname="org.apache.qpid.gentools.Main" fork="true" dir="${gentools.classes}" failonerror="true"> - <arg line='-j -o "${generated-amqp-0-8-dir}/${generated.package}" -t "${basedir}/templates" ${xml.spec.list.0-8}'/> - <classpath> - <pathelement path="${gentools.classes}" /> - <path refid="source.generation.classpathref"/> - </classpath> - </java> - </target> - - <target name="generate-sources" depends="amqp-0-8-generation, amqp-0-10-generation"/> + <target name="generate-sources" depends="amqp-0-10-generation"/> </project> diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpClass.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpClass.java deleted file mode 100644 index 26195da2e3..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpClass.java +++ /dev/null @@ -1,197 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import org.w3c.dom.Node; -import org.w3c.dom.NodeList; - -import java.io.PrintStream; -import java.util.Collection; - -public class AmqpClass implements Printable, NodeAware -{ - - private final AmqpVersionSet _versionSet = new AmqpVersionSet(); - private final AmqpFieldMap _fieldMap = new AmqpFieldMap(); - private final AmqpMethodMap _methodMap = new AmqpMethodMap(); - private final AmqpOrdinalVersionMap _indexMap = new AmqpOrdinalVersionMap(); - - - private final String _name; - private final Generator _generator; - - public AmqpClass(String name, Generator generator) - { - _name = name; - _generator = generator; - } - - public boolean addFromNode(Node classNode, int ordinal, AmqpVersion version) - throws AmqpParseException, AmqpTypeMappingException - { - getVersionSet().add(version); - int index = Utils.getNamedIntegerAttribute(classNode, "index"); - AmqpVersionSet indexVersionSet = getIndexMap().get(index); - if (indexVersionSet != null) - { - indexVersionSet.add(version); - } - else - { - indexVersionSet = new AmqpVersionSet(); - indexVersionSet.add(version); - getIndexMap().put(index, indexVersionSet); - } - NodeList nList = classNode.getChildNodes(); - int fieldCntr = getFieldMap().size(); - for (int i = 0; i < nList.getLength(); i++) - { - Node child = nList.item(i); - if (child.getNodeName().compareTo(Utils.ELEMENT_FIELD) == 0) - { - String fieldName = getGenerator().prepareDomainName(Utils.getNamedAttribute(child, - Utils.ATTRIBUTE_NAME)); - AmqpField thisField = getFieldMap().get(fieldName); - if (thisField == null) - { - thisField = new AmqpField(fieldName, getGenerator()); - getFieldMap().add(fieldName, thisField); - } - if (!thisField.addFromNode(child, fieldCntr++, version)) - { - String className = getGenerator().prepareClassName(Utils.getNamedAttribute(classNode, - Utils.ATTRIBUTE_NAME)); - System.out.println("INFO: Generation supression tag found for field " + - className + "." + fieldName + " - removing."); - thisField.removeVersion(version); - getFieldMap().remove(fieldName); - } - } - else if (child.getNodeName().compareTo(Utils.ELEMENT_METHOD) == 0) - { - String methodName = getGenerator().prepareMethodName(Utils.getNamedAttribute(child, - Utils.ATTRIBUTE_NAME)); - AmqpMethod thisMethod = getMethodMap().get(methodName); - if (thisMethod == null) - { - thisMethod = new AmqpMethod(methodName, getGenerator()); - getMethodMap().put(methodName, thisMethod); - } - if (!thisMethod.addFromNode(child, 0, version)) - { - String className = getGenerator().prepareClassName(Utils.getNamedAttribute(classNode, - Utils.ATTRIBUTE_NAME)); - System.out.println("INFO: Generation supression tag found for method " + - className + "." + methodName + " - removing."); - thisMethod.removeVersion(version); - getMethodMap().remove(methodName); - } - } - else if (child.getNodeName().compareTo(Utils.ELEMENT_CODEGEN) == 0) - { - String value = Utils.getNamedAttribute(child, Utils.ATTRIBUTE_VALUE); - if (value.compareTo("no-gen") == 0) - { - return false; - } - } - } - return true; - } - - public void removeVersion(AmqpVersion version) - { - getIndexMap().removeVersion(version); - getFieldMap().removeVersion(version); - getMethodMap().removeVersion(version); - getVersionSet().remove(version); - } - - public void print(PrintStream out, int marginSize, int tabSize) - { - String margin = Utils.createSpaces(marginSize); - String tab = Utils.createSpaces(tabSize); - out.println(margin + "[C] " + getName() + ": " + getVersionSet()); - - for (Integer thisIndex : getIndexMap().keySet()) - { - AmqpVersionSet indexVersionSet = getIndexMap().get(thisIndex); - out.println(margin + tab + "[I] " + thisIndex + indexVersionSet); - } - - for (String thisFieldName : getFieldMap().keySet()) - { - AmqpField thisField = getFieldMap().get(thisFieldName); - thisField.print(out, marginSize + tabSize, tabSize); - } - - for (String thisMethodName : getMethodMap().keySet()) - { - AmqpMethod thisMethod = getMethodMap().get(thisMethodName); - thisMethod.print(out, marginSize + tabSize, tabSize); - } - } - - public AmqpVersionSet getVersionSet() - { - return _versionSet; - } - - public Generator getGenerator() - { - return _generator; - } - - - public AmqpFieldMap getFieldMap() - { - return _fieldMap; - } - - - public AmqpMethodMap getMethodMap() - { - return _methodMap; - } - - public Collection<AmqpMethod> getMethods() - { - return getMethodMap().values(); - } - - - public String getName() - { - return _name; - } - - - public AmqpOrdinalVersionMap getIndexMap() - { - return _indexMap; - } - - public SingleVersionClass asSingleVersionClass(AmqpVersion version) - { - return new SingleVersionClass(this,version, _generator); - } - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpClassMap.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpClassMap.java deleted file mode 100644 index a27a50d07e..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpClassMap.java +++ /dev/null @@ -1,29 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.util.TreeMap; - -@SuppressWarnings("serial") -public class AmqpClassMap extends TreeMap<String, AmqpClass> -{ - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpConstant.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpConstant.java deleted file mode 100644 index df5bc6c362..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpConstant.java +++ /dev/null @@ -1,191 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.io.PrintStream; -import java.util.TreeMap; - -/** - * @author kpvdr - * Class to represent the <constant> declaration within the AMQP specification. - * Currently, only integer values exist within the specification, however looking forward - * to other possible types in the future, string and double types are also supported. - * <p/> - * The <constant> declaration in the specification contains only two attributes: - * name and value. - * <p/> - * The value of the constant is mapped against the version(s) for which the name is defined. - * This allows for a change in the value rather than the name only from one version to the next. - */ -@SuppressWarnings("serial") -public class AmqpConstant extends TreeMap<String, AmqpVersionSet> - implements Printable, VersionConsistencyCheck, Comparable<AmqpConstant> -{ - /** - * Constant name as defined by the name attribute of the <constant> declaration. - */ - private final String _name; - - /** - * Set of versions for which this constant name is defined. - */ - private final AmqpVersionSet _versionSet; - - /** - * Constructor - * - * @param name Constant name as defined by the name attribute of the <constant> declaration. - * @param value Constant value as defined by the value attribute of the <constant> declaration. - * @param version AMQP version for which this constant is defined - */ - public AmqpConstant(String name, String value, AmqpVersion version) - { - _name = name; - _versionSet = new AmqpVersionSet(version); - AmqpVersionSet valueVersionSet = new AmqpVersionSet(version); - put(value, valueVersionSet); - } - - - /** - * Get the name of this constant. - * - * @return Name of this constant, being the name attribute of the <constant> declaration - * represented by this class. - */ - public String getName() - { - return _name; - } - - /** - * Get the value of this constant as a String. - * - * @param version AMQP version for which this value is required. - * @return Value of this constant, being the value attribute of the <constant> declaration - * represented by this class. - * @throws AmqpTypeMappingException when a value is requested for a version for which it is not - * defined in the AMQP specifications. - */ - public String getStringValue(AmqpVersion version) - throws AmqpTypeMappingException - { - for (String thisValue : keySet()) - { - AmqpVersionSet versionSet = get(thisValue); - if (versionSet.contains(version)) - { - return thisValue; - } - } - throw new AmqpTypeMappingException("Unable to find value for constant \"" + getName() + - "\" for version " + version.toString() + "."); - } - - /** - * Get the value of this constant as an integer. - * - * @param version AMQP version for which this value is required. - * @return Value of this constant, being the value attribute of the <constant> declaration - * represented by this class. - * @throws AmqpTypeMappingException when a value is requested for a version for which it is not - * defined in the AMQP specifications. - */ - public int getIntegerValue(AmqpVersion version) - throws AmqpTypeMappingException - { - return Integer.parseInt(getStringValue(version)); - } - - /** - * Get the value of this constant as a double. - * - * @param version AMQP version for which this value is required. - * @return Value of this constant, being the value attribute of the <constant> declaration - * represented by this class. - * @throws AmqpTypeMappingException when a value is requested for a version for which it is not - * defined in the AMQP specifications. - */ - public double getDoubleValue(AmqpVersion version) - throws AmqpTypeMappingException - { - return Double.parseDouble(getStringValue(version)); - } - - /** - * Get the version set for this constant. It contains the all the versions for which this - * constant name exists. - * - * @return Set of versions for which this constant exists. - */ - public AmqpVersionSet getVersionSet() - { - return _versionSet; - } - - /* (non-Javadoc) - * @see java.lang.Comparable#compareTo(java.lang.Object) - */ - - public int compareTo(AmqpConstant other) - { - int res = getName().compareTo(other.getName()); - if (res != 0) - { - return res; - } - return getVersionSet().compareTo(other.getVersionSet()); - } - - /* (non-Javadoc) - * @see org.apache.qpid.gentools.VersionConsistencyCheck#isVersionConsistent(org.apache.qpid.gentools.AmqpVersionSet) - */ - public boolean isVersionConsistent(AmqpVersionSet globalVersionSet) - { - if (size() != 1) - { - return false; - } - return get(firstKey()).equals(globalVersionSet); - } - - /* (non-Javadoc) - * @see org.apache.qpid.gentools.Printable#print(java.io.PrintStream, int, int) - */ - public void print(PrintStream out, int marginSize, int tabSize) - { - String margin = Utils.createSpaces(marginSize); - String tab = Utils.createSpaces(tabSize); - if (size() == 1) - { - out.println(margin + tab + "[C] " + getName() + " = \"" + firstKey() + "\" " + getVersionSet()); - } - else - { - out.println(margin + tab + "[C] " + getName() + ": " + getVersionSet()); - for (String thisValue : keySet()) - { - out.println(margin + tab + tab + "= \"" + thisValue + "\" " + get(thisValue)); - } - } - } - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpConstantSet.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpConstantSet.java deleted file mode 100644 index ab8b8be61e..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpConstantSet.java +++ /dev/null @@ -1,152 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import org.w3c.dom.Node; -import org.w3c.dom.NodeList; - -import java.io.PrintStream; -import java.util.Iterator; -import java.util.TreeSet; - -/** - * @author kpvdr - * This class implements a set collection for {@link AmqpConstant AmqpConstant} objects, being the collection - * of constants accumulated from various AMQP specification files processed. Each name occurs once only in the set. - * The {@link AmqpConstant AmqpConstant} objects (derived from {@link java.util.TreeMap TreeMap}) keep track of - * the value and version(s) assigned to this name. - */ -@SuppressWarnings("serial") -public class AmqpConstantSet implements Printable, NodeAware //, Comparable<AmqpConstantSet> -{ - private final LanguageConverter _converter; - private final TreeSet<AmqpConstant> _constants = new TreeSet<AmqpConstant>(); - private final AmqpVersionSet _versionSet = new AmqpVersionSet(); - - public AmqpConstantSet(LanguageConverter converter) - { - _converter = converter; - - } - - /* (non-Javadoc) - * @see org.apache.qpid.gentools.NodeAware#addFromNode(org.w3c.dom.Node, int, org.apache.qpid.gentools.AmqpVersion) - */ - public boolean addFromNode(Node node, int ordinal, AmqpVersion version) - throws AmqpParseException, AmqpTypeMappingException - { - _versionSet.add(version); - NodeList nodeList = node.getChildNodes(); - for (int i = 0; i < nodeList.getLength(); i++) - { - Node childNode = nodeList.item(i); - if (childNode.getNodeName().compareTo(Utils.ELEMENT_CONSTANT) == 0) - { - String name = getConverter().prepareConstantName(Utils.getNamedAttribute(childNode, Utils.ATTRIBUTE_NAME)); - String value = Utils.getNamedAttribute(childNode, Utils.ATTRIBUTE_VALUE); - // Find this name in the existing set of objects - boolean foundName = false; - Iterator<AmqpConstant> cItr = _constants.iterator(); - while (cItr.hasNext() && !foundName) - { - AmqpConstant thisConstant = cItr.next(); - if (name.compareTo(thisConstant.getName()) == 0) - { - foundName = true; - thisConstant.getVersionSet().add(version); - // Now, find the value in the map - boolean foundValue = false; - for (String thisValue : thisConstant.keySet()) - { - if (value.compareTo(thisValue) == 0) - { - foundValue = true; - // Add this version to existing version set. - AmqpVersionSet versionSet = thisConstant.get(thisValue); - versionSet.add(version); - } - } - // Check that the value was found - if not, add it - if (!foundValue) - { - thisConstant.put(value, new AmqpVersionSet(version)); - } - } - } - // Check that the name was found - if not, add it - if (!foundName) - { - _constants.add(new AmqpConstant(name, value, version)); - } - } - } - return true; - } - - /* (non-Javadoc) - * @see org.apache.qpid.gentools.Printable#print(java.io.PrintStream, int, int) - */ - public void print(PrintStream out, int marginSize, int tabSize) - { - out.println(Utils.createSpaces(marginSize) + "Constants: "); - for (AmqpConstant thisAmqpConstant : _constants) - { - thisAmqpConstant.print(out, marginSize, tabSize); - } - } - - /* (non-Javadoc) - * @see java.lang.Comparable#compareTo(java.lang.Object) - */ -// public int compareTo(AmqpConstantSet other) -// { -// int res = size() - other.size(); -// if (res != 0) -// return res; -// Iterator<AmqpConstant> cItr = iterator(); -// Iterator<AmqpConstant> oItr = other.iterator(); -// while (cItr.hasNext() && oItr.hasNext()) -// { -// AmqpConstant constant = cItr.next(); -// AmqpConstant oConstant = oItr.next(); -// res = constant.compareTo(oConstant); -// if (res != 0) -// return res; -// } -// return 0; -// } - - public Iterable<? extends AmqpConstant> getContstants() - { - return _constants; - } - - public AmqpVersionSet getVersionSet() - { - return _versionSet; - } - - public LanguageConverter getConverter() - { - return _converter; - } - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpDomain.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpDomain.java deleted file mode 100644 index ba8552a6a6..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpDomain.java +++ /dev/null @@ -1,89 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.io.PrintStream; -import java.util.TreeMap; - -@SuppressWarnings("serial") -public class AmqpDomain extends TreeMap<String, AmqpVersionSet> implements Printable -{ - private final String _domainName; - - public AmqpDomain(String domainName) - { - _domainName = domainName; - } - - public void addDomain(String domainType, AmqpVersion version) throws AmqpParseException - { - AmqpVersionSet versionSet = get(domainType); - if (versionSet == null) // First time, create new entry - { - versionSet = new AmqpVersionSet(); - put(domainType, versionSet); - } - versionSet.add(version); - } - - public String getDomainType(AmqpVersion version) - throws AmqpTypeMappingException - { - for (String thisDomainType : keySet()) - { - AmqpVersionSet versionSet = get(thisDomainType); - if (versionSet.contains(version)) - { - return thisDomainType; - } - } - throw new AmqpTypeMappingException("Unable to find version " + version + "."); - } - - public boolean hasVersion(String type, AmqpVersion v) - { - AmqpVersionSet vs = get(type); - if (vs == null) - { - return false; - } - return vs.contains(v); - } - - public void print(PrintStream out, int marginSize, int tabSize) - { - String margin = Utils.createSpaces(marginSize); - String tab = Utils.createSpaces(tabSize); - out.println(margin + getDomainName() + ":"); - - for (String thisDomainType : keySet()) - { - AmqpVersionSet vs = get(thisDomainType); - out.println(margin + tab + thisDomainType + " : " + vs.toString()); - } - } - - public String getDomainName() - { - return _domainName; - } - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpDomainMap.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpDomainMap.java deleted file mode 100644 index 0cd9d214bd..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpDomainMap.java +++ /dev/null @@ -1,128 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import org.w3c.dom.Node; -import org.w3c.dom.NodeList; - -import java.io.PrintStream; -import java.util.TreeMap; - -@SuppressWarnings("serial") -public class AmqpDomainMap extends TreeMap<String, AmqpDomain> implements Printable, NodeAware -{ - private final LanguageConverter _converter; - - public AmqpDomainMap(LanguageConverter converter) - { - _converter = converter; - - } - - public boolean addFromNode(Node n, int o, AmqpVersion v) - throws AmqpParseException, AmqpTypeMappingException - { - NodeList nl = n.getChildNodes(); - for (int i = 0; i < nl.getLength(); i++) - { - Node c = nl.item(i); - // All versions 0.9 and greater use <domain> for all domains - if (c.getNodeName().compareTo(Utils.ELEMENT_DOMAIN) == 0) - { - String domainName = getConverter().prepareDomainName(Utils.getNamedAttribute(c, Utils.ATTRIBUTE_NAME)); - String type = Utils.getNamedAttribute(c, Utils.ATTRIBUTE_TYPE); - AmqpDomain thisDomain = get(domainName); - if (thisDomain == null) - { - thisDomain = new AmqpDomain(domainName); - put(domainName, thisDomain); - } - thisDomain.addDomain(type, v); - } - // Version(s) 0.8 and earlier use <domain> for all complex domains and use - // attribute <field type=""...> for simple types. Add these simple types to - // domain list - but beware of duplicates! - else if (c.getNodeName().compareTo(Utils.ELEMENT_FIELD) == 0) - { - try - { - String type = getConverter().prepareDomainName(Utils.getNamedAttribute(c, Utils.ATTRIBUTE_TYPE)); - AmqpDomain thisDomain = get(type); - if (thisDomain == null) - { - thisDomain = new AmqpDomain(type); - put(type, thisDomain); - } - if (!thisDomain.hasVersion(type, v)) - { - thisDomain.addDomain(type, v); - } - } - catch (AmqpParseException e) - { - } // Ignore fields without type attribute - } - else if (c.getNodeName().compareTo(Utils.ELEMENT_CLASS) == 0 || - c.getNodeName().compareTo(Utils.ELEMENT_METHOD) == 0) - { - addFromNode(c, 0, v); - } - } - return true; - } - - public String getDomainType(String domainName, AmqpVersion version) - { - AmqpDomain domainType = get(domainName); - // For AMQP 8.0, primitive types were not described as domains, so - // return itself as the type. - if (domainType == null) - { - return domainName; - } - try - { - return domainType.getDomainType(version); - } - catch (AmqpTypeMappingException e) - { - throw new AmqpTypeMappingException("Unable to find domain type for domain \"" + domainName + - "\" version " + version + "."); - } - } - - - public void print(PrintStream out, int marginSize, int tabSize) - { - out.println(Utils.createSpaces(marginSize) + "Domain Map:"); - for (String thisDomainName : keySet()) - { - AmqpDomain domain = get(thisDomainName); - domain.print(out, marginSize + tabSize, tabSize); - } - } - - public LanguageConverter getConverter() - { - return _converter; - } - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpDomainVersionMap.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpDomainVersionMap.java deleted file mode 100644 index e39550b96f..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpDomainVersionMap.java +++ /dev/null @@ -1,62 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.util.ArrayList; -import java.util.TreeMap; - -@SuppressWarnings("serial") -public class AmqpDomainVersionMap extends TreeMap<String, AmqpVersionSet> implements VersionConsistencyCheck -{ - public boolean isVersionConsistent(AmqpVersionSet globalVersionSet) - { - if (size() != 1) - { - return false; - } - return get(firstKey()).equals(globalVersionSet); - } - - public boolean removeVersion(AmqpVersion version) - { - Boolean res = false; - ArrayList<String> removeList = new ArrayList<String>(); - for (String domainName : keySet()) - { - AmqpVersionSet versionSet = get(domainName); - if (versionSet.contains(version)) - { - versionSet.remove(version); - if (versionSet.isEmpty()) - { - removeList.add(domainName); - } - res = true; - } - } - // Get rid of domains no longer in use - for (String domainName : removeList) - { - remove(domainName); - } - return res; - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpField.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpField.java deleted file mode 100644 index 7c721cf913..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpField.java +++ /dev/null @@ -1,269 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import org.w3c.dom.Node; -import org.w3c.dom.NodeList; - -import java.io.PrintStream; -import java.util.ArrayList; -import java.util.HashMap; -import java.util.Map; - -public class AmqpField implements Printable, NodeAware, VersionConsistencyCheck -{ - - private final AmqpVersionSet _versionSet = new AmqpVersionSet(); - private final AmqpDomainVersionMap _domainMap = new AmqpDomainVersionMap(); - private final AmqpOrdinalVersionMap _ordinalMap = new AmqpOrdinalVersionMap(); - - private final String _name; - private final Generator _generator; - - private final Map<AmqpVersion, String> _versionToDomainMap = new HashMap<AmqpVersion, String>(); - private final Map<AmqpVersion, Integer> _versionToOrdinalMap = new HashMap<AmqpVersion, Integer>(); - - - public AmqpField(String name, Generator generator) - { - _name = name; - _generator = generator; - - } - - public boolean addFromNode(Node fieldNode, int ordinal, AmqpVersion version) - throws AmqpParseException, AmqpTypeMappingException - { - _versionSet.add(version); - String domainType; - // Early versions of the spec (8.0) used the "type" attribute instead of "domain" for some fields. - try - { - domainType = _generator.prepareDomainName(Utils.getNamedAttribute(fieldNode, Utils.ATTRIBUTE_DOMAIN)); - } - catch (AmqpParseException e) - { - domainType = _generator.prepareDomainName(Utils.getNamedAttribute(fieldNode, Utils.ATTRIBUTE_TYPE)); - } - AmqpVersionSet thisVersionList = _domainMap.get(domainType); - if (thisVersionList == null) // First time, create new entry - { - thisVersionList = new AmqpVersionSet(); - _domainMap.put(domainType, thisVersionList); - } - - _versionToDomainMap.put(version, domainType); - _versionToOrdinalMap.put(version, ordinal); - - thisVersionList.add(version); - thisVersionList = _ordinalMap.get(ordinal); - if (thisVersionList == null) // First time, create new entry - { - thisVersionList = new AmqpVersionSet(); - _ordinalMap.put(ordinal, thisVersionList); - } - thisVersionList.add(version); - NodeList nList = fieldNode.getChildNodes(); - for (int i = 0; i < nList.getLength(); i++) - { - Node child = nList.item(i); - if (child.getNodeName().compareTo(Utils.ELEMENT_CODEGEN) == 0) - { - String value = Utils.getNamedAttribute(child, Utils.ATTRIBUTE_VALUE); - if (value.compareTo("no-gen") == 0) - { - return false; - } - } - } - return true; - } - - public void removeVersion(AmqpVersion version) - { - _domainMap.removeVersion(version); - _ordinalMap.removeVersion(version); - _versionSet.remove(version); - } - - public boolean isCodeTypeConsistent(LanguageConverter converter) - throws AmqpTypeMappingException - { - if (_domainMap.size() == 1) - { - return true; // By definition - } - ArrayList<String> codeTypeList = new ArrayList<String>(); - for (String thisDomainName : _domainMap.keySet()) - { - AmqpVersionSet versionSet = _domainMap.get(thisDomainName); - String codeType = converter.getGeneratedType(thisDomainName, versionSet.first()); - if (!codeTypeList.contains(codeType)) - { - codeTypeList.add(codeType); - } - } - return codeTypeList.size() == 1; - } - - public boolean isConsistent(Generator generator) - throws AmqpTypeMappingException - { - if (!isCodeTypeConsistent(generator)) - { - return false; - } - if (_ordinalMap.size() != 1) - { - return false; - } - // Since the various doamin names map to the same code type, add the version occurrences - // across all domains to see we have all possible versions covered - int vCntr = 0; - for (String thisDomainName : _domainMap.keySet()) - { - vCntr += _domainMap.get(thisDomainName).size(); - } - return vCntr == generator.getVersionSet().size(); - } - - public boolean isTypeAndNameConsistent(Generator generator) - throws AmqpTypeMappingException - { - if (!isCodeTypeConsistent(generator)) - { - return false; - } - // Since the various doamin names map to the same code type, add the version occurrences - // across all domains to see we have all possible versions covered - int vCntr = 0; - for (String thisDomainName : _domainMap.keySet()) - { - vCntr += _domainMap.get(thisDomainName).size(); - } - return vCntr == getVersionSet().size(); - } - - - public void print(PrintStream out, int marginSize, int tabSize) - { - String margin = Utils.createSpaces(marginSize); - out.println(margin + "[F] " + _name + ": " + _versionSet); - - for (Integer thisOrdinal : _ordinalMap.keySet()) - { - AmqpVersionSet versionList = _ordinalMap.get(thisOrdinal); - out.println(margin + " [O] " + thisOrdinal + " : " + versionList.toString()); - } - - for (String thisDomainName : _domainMap.keySet()) - { - AmqpVersionSet versionList = _domainMap.get(thisDomainName); - out.println(margin + " [D] " + thisDomainName + " : " + versionList.toString()); - } - } - - public boolean isVersionConsistent(AmqpVersionSet globalVersionSet) - { - if (!_versionSet.equals(globalVersionSet)) - { - return false; - } - if (!_domainMap.isVersionConsistent(globalVersionSet)) - { - return false; - } - if (!_ordinalMap.isVersionConsistent(globalVersionSet)) - { - return false; - } - return true; - } - - - public boolean isVersionInterfaceConsistent(AmqpVersionSet globalVersionSet) - { - if (!_versionSet.equals(globalVersionSet)) - { - return false; - } - if (!_domainMap.isVersionConsistent(globalVersionSet)) - { - return false; - } - if (!_ordinalMap.isVersionConsistent(globalVersionSet)) - { - return false; - } - return true; - } - - public String getDomain(AmqpVersion version) - { - return _versionToDomainMap.get(version); - } - - public String getConsistentNativeType() - { - return _generator.getNativeType(_generator.getDomainType(getDomain(_versionSet.first()),_versionSet.first())); - } - - public int getOrdinal(AmqpVersion version) - { - return _versionToOrdinalMap.get(version); - } - - public AmqpVersionSet getVersionSet() - { - return _versionSet; - } - - public AmqpDomainVersionMap getDomainMap() - { - return _domainMap; - } - - public AmqpOrdinalVersionMap getOrdinalMap() - { - return _ordinalMap; - } - - public String getName() - { - return _name; - } - - public LanguageConverter getGenerator() - { - return _generator; - } - - public Map<AmqpVersion, String> getVersionToDomainMap() - { - return _versionToDomainMap; - } - - public Map<AmqpVersion, Integer> getVersionToOrdinalMap() - { - return _versionToOrdinalMap; - } - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpFieldMap.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpFieldMap.java deleted file mode 100644 index 0bb5e03a61..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpFieldMap.java +++ /dev/null @@ -1,452 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.util.ArrayList; -import java.util.Collection; -import java.util.Iterator; -import java.util.Map; -import java.util.Map.Entry; -import java.util.Set; -import java.util.TreeMap; - -@SuppressWarnings("serial") -public class AmqpFieldMap implements VersionConsistencyCheck -{ - - private final TreeMap<String, AmqpField> _map = new TreeMap<String, AmqpField>(); - - private final AmqpVersionSet _versionSet = new AmqpVersionSet(); - - public void removeVersion(AmqpVersion version) - { - String[] fieldNameArray = new String[size()]; - _map.keySet().toArray(fieldNameArray); - Iterator<Entry<String, AmqpField>> iter = _map.entrySet().iterator(); - - while (iter.hasNext()) - { - Entry<String, AmqpField> entry = iter.next(); - entry.getValue().removeVersion(version); - iter.remove(); - } - } - - public int size() - { - return _map.size(); - - } - - public AmqpFieldMap getFieldMapForOrdinal(int ordinal) - { - AmqpFieldMap newMap = new AmqpFieldMap(); - for (AmqpField field : _map.values()) - { - - TreeMap<Integer, AmqpVersionSet> ordinalMap = field.getOrdinalMap(); - AmqpVersionSet ordinalVersions = ordinalMap.get(ordinal); - if (ordinalVersions != null) - { - newMap.add(field.getName(), field); - } - } - return newMap; - } - - public void add(String name, AmqpField field) - { - _versionSet.addAll(field.getVersionSet()); - _map.put(name, field); - } - - public AmqpOrdinalFieldMap getMapForVersion(AmqpVersion version, boolean codeTypeFlag, - LanguageConverter converter) - { - // TODO: REVIEW THIS! There may be a bug here that affects C++ generation (only with >1 version)... - // If version == null (a common scenario) then the version map is built up on the - // basis of first found item, and ignores other version variations. - // This should probably be disallowed by throwing an NPE, as AmqpOrdinalFieldMap cannot - // represent these possibilities. - // *OR* - // Change the structure of AmqpOrdianlFieldMap to allow for the various combinations that - // will result from version variation - but that is what AmqpFieldMap is... :-$ - AmqpOrdinalFieldMap ordinalFieldMap = new AmqpOrdinalFieldMap(); - for (AmqpField field : _map.values()) - { - - if (version == null || field.getVersionSet().contains(version)) - { - // 1. Search for domain name in field domain map with version that matches - String domain = ""; - boolean dFound = false; - for (String thisDomainName : field.getDomainMap().keySet()) - { - domain = thisDomainName; - AmqpVersionSet versionSet = field.getDomainMap().get(domain); - if (version == null || versionSet.contains(version)) - { - if (codeTypeFlag) - { - domain = converter.getGeneratedType(domain, version); - } - dFound = true; - } - } - - // 2. Search for ordinal in field ordianl map with version that matches - int ordinal = -1; - boolean oFound = false; - for (Integer thisOrdinal : field.getOrdinalMap().keySet()) - { - ordinal = thisOrdinal; - AmqpVersionSet versionSet = field.getOrdinalMap().get(ordinal); - if (version == null || versionSet.contains(version)) - { - oFound = true; - } - } - - if (dFound && oFound) - { - String[] fieldDomainPair = {field.getName(), domain}; - ordinalFieldMap.put(ordinal, fieldDomainPair); - } - } - } - return ordinalFieldMap; - } - - public boolean isDomainConsistent(Generator generator, AmqpVersionSet versionSet) - throws AmqpTypeMappingException - { - if (size() != 1) // Only one field for this ordinal - { - return false; - } - return _map.get(_map.firstKey()).isConsistent(generator); - } - - public int getNumFields(AmqpVersion version) - { - int fCntr = 0; - for (AmqpField field : _map.values()) - { - - if (field.getVersionSet().contains(version)) - { - fCntr++; - } - } - return fCntr; - } - - public String parseFieldMap(CommandGenerateMethod commonGenerateMethod, MangledGenerateMethod mangledGenerateMethod, - int indentSize, int tabSize, LanguageConverter converter) - { - String indent = Utils.createSpaces(indentSize); - String cr = Utils.LINE_SEPARATOR; - StringBuffer sb = new StringBuffer(); - - if (commonGenerateMethod == null) - { - // Generate warnings in code if required methods are null. - sb.append(indent + "/*********************************************************" + cr); - sb.append(indent + " * WARNING: Generated code could be missing." + cr); - sb.append(indent + " * In call to parseFieldMap(), generation method was null." + cr); - sb.append(indent + " * Check for NoSuchMethodException on startup." + cr); - sb.append(indent + " *********************************************************/" + cr); - } - - Iterator<Entry<String, AmqpField>> itr = _map.entrySet().iterator(); - while (itr.hasNext()) - { - Entry<String, AmqpField> entry = itr.next(); - String fieldName = entry.getKey(); - AmqpField field = entry.getValue(); - if (field.isCodeTypeConsistent(converter)) - { - // All versions identical - Common declaration - String domainName = field.getDomainMap().firstKey(); - AmqpVersionSet versionSet = field.getDomainMap().get(domainName); - String codeType = converter.getGeneratedType(domainName, versionSet.first()); - if (commonGenerateMethod != null) - { - sb.append(commonGenerateMethod.generate(codeType, field, versionSet, - indentSize, tabSize, itr.hasNext())); - } - } - else if (mangledGenerateMethod != null) // Version-mangled - { - sb.append(mangledGenerateMethod.generate(field, indentSize, tabSize, - itr.hasNext())); - } - } - return sb.toString(); - } - - public String parseFieldMapOrdinally(GenerateMethod generateMethod, BitFieldGenerateMethod bitGenerateMethod, - int indentSize, int tabSize, Generator codeGenerator) - { - String indent = Utils.createSpaces(indentSize); - String cr = Utils.LINE_SEPARATOR; - StringBuffer sb = new StringBuffer(); - - // Generate warnings in code if required methods are null. - if (generateMethod == null || bitGenerateMethod == null) - { - sb.append(indent + "/***********************************************" + cr); - sb.append(indent + " * WARNING: In call to parseFieldMapOrdinally():" + cr); - if (generateMethod == null) - { - sb.append(indent + " * => generateMethod is null." + cr); - } - if (bitGenerateMethod == null) - { - sb.append(indent + " * => bitGenerateMethod is null." + cr); - } - sb.append(indent + " * Generated code could be missing." + cr); - sb.append(indent + " * Check for NoSuchMethodException on startup." + cr); - sb.append(indent + " ***********************************************/" + cr); - } - - /* We must process elements in ordinal order because adjacent booleans (bits) - * must be combined into a single byte (in groups of up to 8). Start with shared - * declarations until an ordinal divergence is found. (For most methods where - * there is no difference between versions, this will simplify the generated - * code. */ - - ArrayList<String> bitFieldList = new ArrayList<String>(); - boolean ordinalDivergenceFlag = false; - int ordinal = 0; - while (ordinal < size() && !ordinalDivergenceFlag) - { - /* Since the getFieldMapOrdinal() function may map more than one Field to - * an ordinal, the number of ordinals may be less than the total number of - * fields in the fieldMap. Check for empty fieldmaps... */ - AmqpFieldMap ordinalFieldMap = getFieldMapForOrdinal(ordinal); - if (ordinalFieldMap.size() > 0) - { - if (ordinalFieldMap.isDomainConsistent(codeGenerator, getVersionSet())) - { - String fieldName = ordinalFieldMap.getFirstFieldName(); - String domain = ordinalFieldMap._map.get(fieldName).getDomainMap().firstKey(); - - String domainType = codeGenerator.getDomainType(domain, - codeGenerator.getVersionSet().first()); - - if (domainType.compareTo("bit") == 0) - { - bitFieldList.add(fieldName); - } - else if (bitFieldList.size() > 0) - { - // End of bit types - handle deferred bit type generation - if (bitGenerateMethod != null) - { - sb.append(bitGenerateMethod.generate(bitFieldList, ordinal, - indentSize, tabSize)); - } - bitFieldList.clear(); - } - if (!ordinalDivergenceFlag) - { - // Defer generation of bit types until all adjacent bits have been - // accounted for. - if (bitFieldList.size() == 0 && generateMethod != null) - { - sb.append(generateMethod.generate(domainType, fieldName, ordinal, - indentSize, tabSize)); - } - } - ordinal++; - } - else - { - ordinalDivergenceFlag = true; - } - } - } - - // Check if there is still more to do under a version-specific breakout - if (ordinalDivergenceFlag && ordinal < size()) - { - // 1. Cycle through all versions in order, create outer if(version) structure - AmqpVersion[] versionArray = new AmqpVersion[getVersionSet().size()]; - getVersionSet().toArray(versionArray); - for (int v = 0; v < versionArray.length; v++) - { - sb.append(indent); - if (v > 0) - { - sb.append("else "); - } - sb.append("if (major == " + versionArray[v].getMajor() + " && minor == " + - versionArray[v].getMinor() + ")" + cr); - sb.append(indent + "{" + cr); - - // 2. Cycle though each ordinal from where we left off in the loop above. - ArrayList<String> bitFieldList2 = new ArrayList<String>(bitFieldList); - for (int o = ordinal; o < size(); o++) - { - AmqpFieldMap ordinalFieldMap = getFieldMapForOrdinal(o); - if (ordinalFieldMap.size() > 0) - { - // 3. Cycle through each of the fields that have this ordinal. - Iterator<Map.Entry<String, AmqpField>> i = ordinalFieldMap._map.entrySet().iterator(); - while (i.hasNext()) - { - - Map.Entry<String, AmqpField> entry = i.next(); - AmqpField field = entry.getValue(); - String fieldName = entry.getKey(); - - // 4. Some fields may have more than one ordinal - match by both - // ordinal and version. - Iterator<Integer> j = field.getOrdinalMap().keySet().iterator(); - while (j.hasNext()) - { - int thisOrdinal = j.next(); - AmqpVersionSet v1 = field.getOrdinalMap().get(thisOrdinal); - if (thisOrdinal == o && v1.contains(versionArray[v])) - { - // 5. Now get the domain for this version - int domainCntr = 0; - Iterator<String> k = field.getDomainMap().keySet().iterator(); - while (k.hasNext()) - { - // Mangle domain-divergent field names - String mangledFieldName = fieldName; - if (field.getDomainMap().size() > 1) - { - mangledFieldName += "_" + (domainCntr++); - } - String domainName = k.next(); - AmqpVersionSet v2 = field.getDomainMap().get(domainName); - if (v2.contains(versionArray[v])) - { - // 6. (Finally!!) write the declaration - String domainType = codeGenerator.getDomainType(domainName, - versionArray[v]); - if (domainType.compareTo("bit") == 0) - { - bitFieldList2.add(mangledFieldName); - } - else if (bitFieldList2.size() > 0) - { - // End of bit types - handle deferred bit type generation - if (bitGenerateMethod != null) - { - sb.append(bitGenerateMethod.generate( - bitFieldList2, o, indentSize + tabSize, - tabSize)); - } - bitFieldList2.clear(); - } - // Defer generation of bit types until all adjacent bits have - // been accounted for. - if (bitFieldList2.size() == 0 && generateMethod != null) - { - sb.append(generateMethod.generate(domainType, - mangledFieldName, o, indentSize + tabSize, tabSize)); - } - } - } - } - } - } - } - } - // Check for remaining deferred bits - if (bitFieldList2.size() > 0 && bitGenerateMethod != null) - { - sb.append(bitGenerateMethod.generate(bitFieldList2, size(), - indentSize + tabSize, tabSize)); - } - sb.append(indent + "}" + cr); - } - } - // Check for remaining deferred bits - else if (bitFieldList.size() > 0 && bitGenerateMethod != null) - { - sb.append(bitGenerateMethod.generate(bitFieldList, size(), - indentSize, tabSize)); - } - return sb.toString(); - } - - private String getFirstFieldName() - { - return _map.firstKey(); - } - - public boolean isVersionConsistent(AmqpVersionSet globalVersionSet) - { - for (String thisFieldName : _map.keySet()) - { - AmqpField field = _map.get(thisFieldName); - if (!field.isVersionConsistent(globalVersionSet)) - { - return false; - } - } - return true; - } - - public boolean isVersionInterfaceConsistent(AmqpVersionSet globalVersionSet) - { - for (String thisFieldName : _map.keySet()) - { - AmqpField field = _map.get(thisFieldName); - if (!field.isVersionInterfaceConsistent(globalVersionSet)) - { - return false; - } - } - return true; - } - - - public AmqpVersionSet getVersionSet() - { - return _versionSet; - } - - public Collection<AmqpField> values() - { - return _map.values(); - } - - public AmqpField get(String fieldName) - { - return _map.get(fieldName); - } - - public void remove(String fieldName) - { - _map.remove(fieldName); - } - - public Set<String> keySet() - { - return _map.keySet(); - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpFlagMap.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpFlagMap.java deleted file mode 100644 index 5993a1b715..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpFlagMap.java +++ /dev/null @@ -1,77 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.util.ArrayList; -import java.util.TreeMap; - -@SuppressWarnings("serial") -public class AmqpFlagMap extends TreeMap<Boolean, AmqpVersionSet> implements VersionConsistencyCheck -{ - public boolean isSet() - { - return containsKey(true); - } - - public String toString() - { - AmqpVersionSet versionSet = get(true); - if (versionSet != null) - { - return versionSet.toString(); - } - return ""; - } - - public boolean isVersionConsistent(AmqpVersionSet globalVersionSet) - { - if (size() != 1) - { - return false; - } - return get(firstKey()).equals(globalVersionSet); - } - - public boolean removeVersion(AmqpVersion version) - { - Boolean res = false; - ArrayList<Boolean> removeList = new ArrayList<Boolean>(); - for (Boolean flag : keySet()) - { - AmqpVersionSet versionSet = get(flag); - if (versionSet.contains(version)) - { - versionSet.remove(version); - if (versionSet.isEmpty()) - { - removeList.add(flag); - } - res = true; - } - } - // Get rid of flags no longer in use - for (Boolean flag : removeList) - { - remove(flag); - } - return res; - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpMethod.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpMethod.java deleted file mode 100644 index 4ec39b209e..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpMethod.java +++ /dev/null @@ -1,351 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import org.w3c.dom.Node; -import org.w3c.dom.NodeList; - -import java.io.PrintStream; -import java.util.HashMap; -import java.util.Map; -import java.util.Collection; -import java.util.concurrent.atomic.AtomicInteger; - -public class AmqpMethod implements Printable, NodeAware, VersionConsistencyCheck -{ - private final AmqpVersionSet _versionSet = new AmqpVersionSet(); - private final AmqpFieldMap _fieldMap = new AmqpFieldMap(); - - private final AmqpOrdinalVersionMap _indexMap = new AmqpOrdinalVersionMap(); - private final AmqpFlagMap _clientMethodFlagMap = new AmqpFlagMap(); // Method called on client (<chassis name="server"> in XML) - private final AmqpFlagMap _serverMethodFlagMap = new AmqpFlagMap(); // Method called on server (<chassis name="client"> in XML) - - private final Map<AmqpVersion, AmqpFieldMap> _versionToFieldsMap = new HashMap<AmqpVersion, AmqpFieldMap>(); - - private final Map<AmqpVersion, AtomicInteger> _versionToFieldCount = new HashMap<AmqpVersion, AtomicInteger>(); - - private final String _name; - private final Generator _generator; - - - public AmqpMethod(String name, Generator generator) - { - _name = name; - _generator = generator; - } - - public boolean addFromNode(Node methodNode, int ordinal, AmqpVersion version) - throws AmqpParseException, AmqpTypeMappingException - { - _versionSet.add(version); - boolean serverChassisFlag = false; - boolean clientChassisFlag = false; - int index = Utils.getNamedIntegerAttribute(methodNode, "index"); - AmqpVersionSet indexVersionSet = _indexMap.get(index); - if (indexVersionSet != null) - { - indexVersionSet.add(version); - } - else - { - indexVersionSet = new AmqpVersionSet(); - indexVersionSet.add(version); - _indexMap.put(index, indexVersionSet); - } - NodeList nList = methodNode.getChildNodes(); - AtomicInteger fieldCntr = _versionToFieldCount.get(version); - if(fieldCntr == null) - { - fieldCntr = new AtomicInteger(0); - _versionToFieldCount.put(version, fieldCntr); - } - for (int i = 0; i < nList.getLength(); i++) - { - Node child = nList.item(i); - if (child.getNodeName().compareTo(Utils.ELEMENT_FIELD) == 0) - { - String fieldName = _generator.prepareDomainName(Utils.getNamedAttribute(child, - Utils.ATTRIBUTE_NAME)); - AmqpField thisField = _fieldMap.get(fieldName); - AmqpFieldMap versionSpecificFieldMap = _versionToFieldsMap.get(version); - if (versionSpecificFieldMap == null) - { - versionSpecificFieldMap = new AmqpFieldMap(); - _versionToFieldsMap.put(version, versionSpecificFieldMap); - } - - - if (thisField == null) - { - thisField = new AmqpField(fieldName, _generator); - _fieldMap.add(fieldName, thisField); - } - - AmqpField versionSpecificField = new AmqpField(fieldName, _generator); - versionSpecificFieldMap.add(fieldName, versionSpecificField); - - versionSpecificField.addFromNode(child, fieldCntr.intValue(), version); - - if (!thisField.addFromNode(child, fieldCntr.getAndIncrement(), version)) - { - String className = _generator.prepareClassName(Utils.getNamedAttribute(methodNode.getParentNode(), - Utils.ATTRIBUTE_NAME)); - String methodName = _generator.prepareMethodName(Utils.getNamedAttribute(methodNode, - Utils.ATTRIBUTE_NAME)); - System.out.println("INFO: Generation supression tag found for field " + - className + "." + methodName + "." + fieldName + " - removing."); - thisField.removeVersion(version); - _fieldMap.remove(fieldName); - } - } - else if (child.getNodeName().compareTo(Utils.ELEMENT_CHASSIS) == 0) - { - String chassisName = Utils.getNamedAttribute(child, Utils.ATTRIBUTE_NAME); - if (chassisName.compareTo("server") == 0) - { - serverChassisFlag = true; - } - else if (chassisName.compareTo("client") == 0) - { - clientChassisFlag = true; - } - } - else if (child.getNodeName().compareTo(Utils.ELEMENT_CODEGEN) == 0) - { - String value = Utils.getNamedAttribute(child, Utils.ATTRIBUTE_VALUE); - if (value.compareTo("no-gen") == 0) - { - return false; - } - } - } - processChassisFlags(serverChassisFlag, clientChassisFlag, version); - return true; - } - - public void removeVersion(AmqpVersion version) - { - _clientMethodFlagMap.removeVersion(version); - _serverMethodFlagMap.removeVersion(version); - _indexMap.removeVersion(version); - _fieldMap.removeVersion(version); - _versionSet.remove(version); - } - - public void print(PrintStream out, int marginSize, int tabSize) - { - String margin = Utils.createSpaces(marginSize); - String tab = Utils.createSpaces(tabSize); - out.println(margin + "[M] " + _name + " {" + (_serverMethodFlagMap.isSet() ? "S " + - _serverMethodFlagMap + ( - _clientMethodFlagMap.isSet() ? ", " : "") : "") + - (_clientMethodFlagMap.isSet() - ? "C " + _clientMethodFlagMap : "") + "}" + ": " + - _versionSet); - - for (Integer thisIndex : _indexMap.keySet()) - { - AmqpVersionSet indexVersionSet = _indexMap.get(thisIndex); - out.println(margin + tab + "[I] " + thisIndex + indexVersionSet); - } - - for (String thisFieldName : _fieldMap.keySet()) - { - AmqpField thisField = _fieldMap.get(thisFieldName); - thisField.print(out, marginSize + tabSize, tabSize); - } - } - - protected void processChassisFlags(boolean serverFlag, boolean clientFlag, AmqpVersion version) - { - AmqpVersionSet versionSet = _serverMethodFlagMap.get(serverFlag); - if (versionSet != null) - { - versionSet.add(version); - } - else - { - versionSet = new AmqpVersionSet(); - versionSet.add(version); - _serverMethodFlagMap.put(serverFlag, versionSet); - } - - versionSet = _clientMethodFlagMap.get(clientFlag); - if (versionSet != null) - { - versionSet.add(version); - } - else - { - versionSet = new AmqpVersionSet(); - versionSet.add(version); - _clientMethodFlagMap.put(clientFlag, versionSet); - } - } - - public AmqpOverloadedParameterMap getOverloadedParameterLists(AmqpVersionSet globalVersionSet, - Generator generator) - throws AmqpTypeMappingException - { - AmqpOverloadedParameterMap parameterVersionMap = new AmqpOverloadedParameterMap(); - for (AmqpVersion thisVersion : globalVersionSet) - { - AmqpOrdinalFieldMap ordinalFieldMap = _fieldMap.getMapForVersion(thisVersion, true, generator); - AmqpVersionSet methodVersionSet = parameterVersionMap.get(ordinalFieldMap); - if (methodVersionSet == null) - { - methodVersionSet = new AmqpVersionSet(); - methodVersionSet.add(thisVersion); - parameterVersionMap.put(ordinalFieldMap, methodVersionSet); - } - else - { - methodVersionSet.add(thisVersion); - } - } - return parameterVersionMap; - } - - public boolean isVersionInterfaceConsistent() - { - return isVersionInterfaceConsistent(_generator.getVersionSet()); - } - - public boolean isVersionInterfaceConsistent(AmqpVersionSet globalVersionSet) - { - if (!_versionSet.equals(globalVersionSet)) - { - return false; - } - if (!_clientMethodFlagMap.isVersionConsistent(globalVersionSet)) - { - return false; - } - if (!_serverMethodFlagMap.isVersionConsistent(globalVersionSet)) - { - return false; - } - if (!_fieldMap.isVersionInterfaceConsistent(globalVersionSet)) - { - return false; - } - return true; - } - - public boolean isVersionConsistent() - { - return isVersionConsistent(_generator.getVersionSet()); - } - - - public boolean isVersionConsistent(AmqpVersionSet globalVersionSet) - { - return isVersionInterfaceConsistent(globalVersionSet) - && _indexMap.isVersionConsistent(globalVersionSet) - && _fieldMap.isVersionConsistent(globalVersionSet); - } - - public AmqpVersionSet getVersionSet() - { - return _versionSet; - } - - public AmqpFieldMap getFieldMap() - { - return _fieldMap; - } - - public AmqpOrdinalVersionMap getIndexMap() - { - return _indexMap; - } - - public AmqpFlagMap getClientMethodFlagMap() - { - return _clientMethodFlagMap; - } - - public AmqpFlagMap getServerMethodFlagMap() - { - return _serverMethodFlagMap; - } - - public Map<AmqpVersion, AmqpFieldMap> getVersionToFieldsMap() - { - return _versionToFieldsMap; - } - - public String getName() - { - return _name; - } - - public LanguageConverter getGenerator() - { - return _generator; - } - - public SingleVersionMethod asSingleVersionMethod(AmqpVersion version) - { - return new SingleVersionMethod(this, version, _generator); - } - - public Collection<AmqpField> getFields() - { - return _fieldMap.values(); - } - - public boolean isCommon(AmqpField field) - { - return field.getVersionSet().equals(getVersionSet()) && field.isTypeAndNameConsistent(_generator); - } - - public boolean isConsistentServerMethod() - { - AmqpVersionSet serverVersions = _serverMethodFlagMap.get(true); - return (serverVersions != null) && serverVersions.containsAll(_generator.getVersionSet()); - } - - - public boolean isConsistentClientMethod() - { - AmqpVersionSet clientVersions = _clientMethodFlagMap.get(true); - return (clientVersions != null) && clientVersions.containsAll(_generator.getVersionSet()); - } - - public boolean isServerMethod(AmqpVersion version) - { - AmqpVersionSet serverVersions = _serverMethodFlagMap.get(true); - return (serverVersions != null) && serverVersions.contains(version); - } - - - public boolean isClientMethod(AmqpVersion version) - { - AmqpVersionSet clientVersions = _clientMethodFlagMap.get(true); - return (clientVersions != null) && clientVersions.contains(version); - } - - public boolean inAllVersions() - { - return _versionSet.containsAll(_generator.getVersionSet()); - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpMethodMap.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpMethodMap.java deleted file mode 100644 index d98dab4a39..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpMethodMap.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.util.TreeMap; - -@SuppressWarnings("serial") -public class AmqpMethodMap extends TreeMap<String, AmqpMethod> -{ - public void removeVersion(AmqpVersion version) - { - for (String methodName : keySet()) - { - get(methodName).removeVersion(version); - } - } - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpModel.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpModel.java deleted file mode 100644 index 45f0adb18d..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpModel.java +++ /dev/null @@ -1,132 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import org.w3c.dom.Node; -import org.w3c.dom.NodeList; - -import java.io.PrintStream; -import java.util.HashMap; -import java.util.Map; -import java.util.Collection; - -public class AmqpModel implements Printable, NodeAware -{ - private final Generator _generator; - private final AmqpClassMap classMap = new AmqpClassMap(); - private final AmqpVersionSet _versionSet = new AmqpVersionSet(); - - private final Map<AmqpVersion, AmqpClassMap> _versionToClassMapMap = new HashMap<AmqpVersion, AmqpClassMap>(); - - public AmqpModel(Generator generator) - { - _generator = generator; - } - - public AmqpClassMap getAmqpClassMap(AmqpVersion version) - { - return _versionToClassMapMap.get(version); - } - - - public AmqpVersionSet getVersionSet() - { - return _versionSet; - } - - public boolean addFromNode(Node n, int o, AmqpVersion version) - throws AmqpParseException, AmqpTypeMappingException - { - _versionSet.add(version); - NodeList nList = n.getChildNodes(); - - AmqpClassMap versionSpecificClassMap = _versionToClassMapMap.get(version); - - if (versionSpecificClassMap == null) - { - versionSpecificClassMap = new AmqpClassMap(); - _versionToClassMapMap.put(version, versionSpecificClassMap); - } - - int eCntr = 0; - for (int i = 0; i < nList.getLength(); i++) - { - Node c = nList.item(i); - if (c.getNodeName().compareTo(Utils.ELEMENT_CLASS) == 0) - { - String className = _generator.prepareClassName(Utils.getNamedAttribute(c, Utils.ATTRIBUTE_NAME)); - AmqpClass thisClass = classMap.get(className); - if (thisClass == null) - { - thisClass = new AmqpClass(className, _generator); - classMap.put(className, thisClass); - } - - AmqpClass versionSpecificClass = new AmqpClass(className, _generator); - versionSpecificClassMap.put(className, versionSpecificClass); - - versionSpecificClass.addFromNode(c, eCntr, version); - - if (!thisClass.addFromNode(c, eCntr++, version)) - { - System.out.println("INFO: Generation supression tag found for class " + className + " - removing."); - thisClass.removeVersion(version); - classMap.remove(className); - } - } - } - return true; - } - - public void print(PrintStream out, int marginSize, int tabSize) - { - out.println(Utils.createSpaces(marginSize) + - "[C]=class; [M]=method; [F]=field; [D]=domain; [I]=index; [O]=ordinal" + Utils.LINE_SEPARATOR); - out.println(Utils.createSpaces(marginSize) + "Model:"); - - for (String thisClassName : classMap.keySet()) - { - AmqpClass thisClass = classMap.get(thisClassName); - thisClass.print(out, marginSize + tabSize, tabSize); - } - } - - public LanguageConverter getGenerator() - { - return _generator; - } - - public AmqpClassMap getClassMap() - { - return classMap; - } - - - public Collection<AmqpClass> getClasses() - { - return classMap.values(); - } - - public SingleVersionModel asSingleVersionModel() - { - return new SingleVersionModel(this, getVersionSet().first(), _generator); - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpOrdinalFieldMap.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpOrdinalFieldMap.java deleted file mode 100644 index 0633eff1e1..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpOrdinalFieldMap.java +++ /dev/null @@ -1,96 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.util.Iterator; -import java.util.Set; -import java.util.TreeMap; - -@SuppressWarnings("serial") -public class AmqpOrdinalFieldMap extends TreeMap<Integer, String[]> implements Comparable -{ - - - public int compareTo(Object obj) - { - AmqpOrdinalFieldMap o = (AmqpOrdinalFieldMap) obj; - Set<Integer> thisKeySet = keySet(); - Set<Integer> oKeySet = o.keySet(); - if (!thisKeySet.equals(oKeySet)) // Not equal, but why? - { - // Size difference - int sizeDiff = thisKeySet.size() - oKeySet.size(); // -ve if this < other - if (sizeDiff != 0) - { - return sizeDiff; - } - // Conetent difference - Iterator<Integer> itr = thisKeySet.iterator(); - Iterator<Integer> oItr = oKeySet.iterator(); - while (itr.hasNext() && oItr.hasNext()) - { - int diff = itr.next() - oItr.next(); // -ve if this < other - if (diff != 0) - { - return diff; - } - } - // We should never get here... - System.err.println("AmqpOrdinalFieldMap.compareTo(): " + - "WARNING - unable to find cause of keySet difference."); - } - // Keys are equal, now check the String[]s - Iterator<Integer> itr = thisKeySet.iterator(); - Iterator<Integer> oItr = oKeySet.iterator(); - while (itr.hasNext() && oItr.hasNext()) - { - String[] thisPair = get(itr.next()); - String[] oPair = o.get(oItr.next()); - // Size difference - int sizeDiff = thisPair.length - oPair.length; // -ve if this < other - if (sizeDiff != 0) - { - return sizeDiff; - } - // Conetent difference - for (int i = 0; i < thisPair.length; i++) - { - int diff = thisPair[i].compareTo(oPair[i]); - if (diff != 0) - { - return diff; - } - } - } - return 0; - } - - public String toString() - { - StringBuffer sb = new StringBuffer(); - for (Integer thisOrdinal : keySet()) - { - String[] pair = get(thisOrdinal); - sb.append("[" + thisOrdinal + "] " + pair[0] + " : " + pair[1] + Utils.LINE_SEPARATOR); - } - return sb.toString(); - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpOrdinalVersionMap.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpOrdinalVersionMap.java deleted file mode 100644 index fede88631a..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpOrdinalVersionMap.java +++ /dev/null @@ -1,76 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.util.ArrayList; -import java.util.TreeMap; - -@SuppressWarnings("serial") -public class AmqpOrdinalVersionMap extends TreeMap<Integer, AmqpVersionSet> implements VersionConsistencyCheck -{ - public boolean isVersionConsistent(AmqpVersionSet globalVersionSet) - { - if (size() != 1) - { - return false; - } - return get(firstKey()).equals(globalVersionSet); - } - - public int getOrdinal(AmqpVersion version) - throws AmqpTypeMappingException - { - for (Integer thisOrdinal : keySet()) - { - AmqpVersionSet versionSet = get(thisOrdinal); - if (versionSet.contains(version)) - { - return thisOrdinal; - } - } - throw new AmqpTypeMappingException("Unable to locate version " + version + " in ordianl version map."); - } - - public boolean removeVersion(AmqpVersion version) - { - Boolean res = false; - ArrayList<Integer> removeList = new ArrayList<Integer>(); - for (Integer ordinal : keySet()) - { - AmqpVersionSet versionSet = get(ordinal); - if (versionSet.contains(version)) - { - versionSet.remove(version); - if (versionSet.isEmpty()) - { - removeList.add(ordinal); - } - res = true; - } - } - // Get rid of ordinals no longer in use - for (Integer ordinal : removeList) - { - remove(ordinal); - } - return res; - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpOverloadedParameterMap.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpOverloadedParameterMap.java deleted file mode 100644 index 10978d0e4a..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpOverloadedParameterMap.java +++ /dev/null @@ -1,29 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.util.TreeMap; - -@SuppressWarnings("serial") -public class AmqpOverloadedParameterMap extends TreeMap<AmqpOrdinalFieldMap, AmqpVersionSet> -{ - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpTemplateException.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpTemplateException.java deleted file mode 100644 index 1ac09ea453..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpTemplateException.java +++ /dev/null @@ -1,30 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -@SuppressWarnings("serial") -public class AmqpTemplateException extends RuntimeException -{ - public AmqpTemplateException(String msg) - { - super(msg); - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpTypeMappingException.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpTypeMappingException.java deleted file mode 100644 index 127a8835b0..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpTypeMappingException.java +++ /dev/null @@ -1,30 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -@SuppressWarnings("serial") -public class AmqpTypeMappingException extends RuntimeException -{ - public AmqpTypeMappingException(String msg) - { - super(msg); - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpVersion.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpVersion.java deleted file mode 100644 index dbeef1b895..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpVersion.java +++ /dev/null @@ -1,72 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -public class AmqpVersion implements Comparable<AmqpVersion> -{ - private final int _major; - private final int _minor; - - public AmqpVersion(int major, int minor) - { - _major = major; - _minor = minor; - } - - public AmqpVersion(AmqpVersion version) - { - _major = version.getMajor(); - _minor = version.getMinor(); - } - - public int getMajor() - { - return _major; - } - - public int getMinor() - { - return _minor; - } - - public int compareTo(AmqpVersion v) - { - if (_major != v.getMajor()) - { - return _major - v.getMajor(); - } - if (_minor != v.getMinor()) - { - return _minor - v.getMinor(); - } - return 0; - } - - public String namespace() - { - return "ver_" + _major + "_" + _minor; - } - - public String toString() - { - return _major + "-" + _minor; - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpVersionSet.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpVersionSet.java deleted file mode 100644 index 6419e23a1e..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/AmqpVersionSet.java +++ /dev/null @@ -1,79 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.io.PrintStream; -import java.util.Iterator; -import java.util.TreeSet; - -@SuppressWarnings("serial") -public class AmqpVersionSet extends TreeSet<AmqpVersion> implements Printable, Comparable<AmqpVersionSet> -{ - public AmqpVersionSet() - { - super(); - } - - public AmqpVersionSet(AmqpVersion version) - { - super(); - add(version); - } - - public AmqpVersion find(AmqpVersion version) - { - for (AmqpVersion v : this) - { - if (v.compareTo(version) == 0) - { - return v; - } - } - return null; - } - - public void print(PrintStream out, int marginSize, int tabSize) - { - out.print(Utils.createSpaces(marginSize) + "Version Set: " + toString() + Utils.LINE_SEPARATOR); - } - - public int compareTo(AmqpVersionSet other) - { - int res = size() - other.size(); - if (res != 0) - { - return res; - } - Iterator<AmqpVersion> vItr = iterator(); - Iterator<AmqpVersion> oItr = other.iterator(); - while (vItr.hasNext() && oItr.hasNext()) - { - AmqpVersion version = vItr.next(); - AmqpVersion oVersion = oItr.next(); - res = version.compareTo(oVersion); - if (res != 0) - { - return res; - } - } - return 0; - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/BitFieldGenerateMethod.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/BitFieldGenerateMethod.java deleted file mode 100644 index d85510ee98..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/BitFieldGenerateMethod.java +++ /dev/null @@ -1,29 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - - -import java.util.List; - -public interface BitFieldGenerateMethod -{ - String generate(List<String> bitFieldList, int ordinal, int indentSize, int tabSize); -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/CommandGenerateMethod.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/CommandGenerateMethod.java deleted file mode 100644 index 641f50c3f8..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/CommandGenerateMethod.java +++ /dev/null @@ -1,26 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -public interface CommandGenerateMethod -{ - String generate(String codeType, AmqpField field, AmqpVersionSet versionSet, int indentSize, int tabSize, boolean notLast); -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/ConsolidatedField.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/ConsolidatedField.java deleted file mode 100644 index 9ab7eb178b..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/ConsolidatedField.java +++ /dev/null @@ -1,120 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.util.List; -import java.util.ArrayList; -import java.util.Collection; -import java.util.Collections; - -/** - * Created by IntelliJ IDEA. - * User: U146758 - * Date: 06-Mar-2007 - * Time: 09:22:21 - * To change this template use File | Settings | File Templates. - */ -public class ConsolidatedField -{ - private final String _name; - private final String _type; - private final List<String> _underlyingFields = new ArrayList<String>(); - private final Generator _generator; - private boolean _isConsolidated; - - public ConsolidatedField(Generator generator, String name, String type) - { - this(generator,name,type,name,false); - } - - public ConsolidatedField(Generator generator, String name, String type, String firstField) - { - this(generator,name,type,firstField,true); - } - - public ConsolidatedField(Generator generator, String name, String type, String firstField, boolean consolidated) - { - - _generator = generator; - _name = name; - _type = type; - _isConsolidated = consolidated; - _underlyingFields.add(firstField); - - } - - - public void setConsolidated(boolean consolidated) - { - _isConsolidated = consolidated; - } - - public String getName() - { - return _name; - } - - public String getType() - { - return _type; - } - - public String getNativeType() - { - return _generator.getNativeType(_type); - } - - public String getEncodingType() - { - return _generator.getEncodingType(_type); - } - - public void add(String name) - { - _underlyingFields.add(name); - } - - public Collection<String> getUnderlyingFields() - { - return Collections.unmodifiableCollection(_underlyingFields); - } - - public int getPosition(String fieldName) - { - return _underlyingFields.indexOf(fieldName); - } - - public boolean isConsolidated() - { - return _isConsolidated; - } - - public boolean isFixedSize() - { - return _generator.isFixedSizeType( getType() ); - } - - public int getSize() - { - return _generator.getTypeSize( getType() ); - } - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/CppGenerator.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/CppGenerator.java deleted file mode 100644 index 4f58cba34e..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/CppGenerator.java +++ /dev/null @@ -1,1716 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.io.File; -import java.util.ArrayList; -import java.util.Iterator; -import java.util.TreeMap; - -public class CppGenerator extends Generator -{ - protected static final String versionNamespaceStartToken = "${version_namespace_start}"; - protected static final String versionNamespaceEndToken = "${version_namespace_end}"; - - // TODO: Move this to parent class - protected static final int FIELD_NAME = 0; - protected static final int FIELD_CODE_TYPE = 1; - - /** - * A complete list of C++ reserved words. The names of varous XML elements within the AMQP - * specification file are used for C++ identifier names in the generated code. Each proposed - * name is checked against this list and is modified (by adding an '_' to the end of the - * name - see function parseForReservedWords()) if found to be present. - */ - protected static final String[] cppReservedWords = {"and", "and_eq", "asm", "auto", "bitand", - "bitor", "bool", "break", "case", "catch", "char", "class", "compl", "const", "const_cast", - "continue", "default", "delete", "do", "DomainInfo", "double", "dynamic_cast", "else", - "enum", "explicit", "extern", "false", "float", "for", "friend", "goto", "if", "inline", - "int", "long", "mutable", "namespace", "new", "not", "not_eq", "operator", "or", "or_eq", - "private", "protected", "public", "register", "reinterpret_cast", "return", "short", - "signed", "sizeof", "static", "static_cast", "struct", "switch", "template", "this", - "throw", "true", "try", "typedef", "typeid", "typename", "union", "unsigned", "using", - "virtual", "void", "volatile", "wchar_t", "while", "xor", "xor_eq"}; - - /** - * Although not reserved words, the following list of variable names that may cause compile - * problems within a C++ environment because they clash with common #includes. The names of - * varous XML elements within the AMQP specification file are used for C++ identifier names - * in the generated code. Each proposed name is checked against this list and is modified - * (by adding an '_' to the end of the name - see function parseForReservedWords()) if found - * to be present. This list is best added to on an as-needed basis. - */ - protected static final String[] cppCommonDefines = {"string"}; - - // TODO: Move this to the Generator superclass? - protected boolean quietFlag; // Supress warning messages to the console - - private class DomainInfo - { - public String type; - public String size; - public String encodeExpression; - public String decodeExpression; - - public DomainInfo(String domain, String size, String encodeExpression, - String decodeExpression) - { - this.type = domain; - this.size = size; - this.encodeExpression = encodeExpression; - this.decodeExpression = decodeExpression; - } - } - - private static TreeMap<String, DomainInfo> typeMap = new TreeMap<String, DomainInfo>(); - - public CppGenerator() - { - super(); - quietFlag = true; - // Load C++ type and size maps. - // Adjust or add to these lists as new types are added/defined. - // The char '#' will be replaced by the field variable name (any type). - // The char '~' will be replaced by the compacted bit array size (type bit only). - typeMap.put("bit", new DomainInfo( - "bool", // type - "~", // size - "", // encodeExpression - "")); // decodeExpression - typeMap.put("content", new DomainInfo( - "Content", // type - "#.size()", // size - "buffer.putContent(#)", // encodeExpression - "buffer.getContent(#)")); // decodeExpression - typeMap.put("long", new DomainInfo( - "u_int32_t", // type - "4", // size - "buffer.putLong(#)", // encodeExpression - "# = buffer.getLong()")); // decodeExpression - typeMap.put("longlong", new DomainInfo( - "u_int64_t", // type - "8", // size - "buffer.putLongLong(#)", // encodeExpression - "# = buffer.getLongLong()")); // decodeExpression - typeMap.put("longstr", new DomainInfo( - "string", // type - "4 + #.length()", // size - "buffer.putLongString(#)", // encodeExpression - "buffer.getLongString(#)")); // decodeExpression - typeMap.put("octet", new DomainInfo( - "u_int8_t", // type - "1", // size - "buffer.putOctet(#)", // encodeExpression - "# = buffer.getOctet()")); // decodeExpression - typeMap.put("short", new DomainInfo( - "u_int16_t", // type - "2", // size - "buffer.putShort(#)", // encodeExpression - "# = buffer.getShort()")); // decodeExpression - typeMap.put("shortstr", new DomainInfo( - "string", // type - "1 + #.length()", // size - "buffer.putShortString(#)", // encodeExpression - "buffer.getShortString(#)")); // decodeExpression - typeMap.put("table", new DomainInfo( - "FieldTable", // type - "#.size()", // size - "buffer.putFieldTable(#)", // encodeExpression - "buffer.getFieldTable(#)")); // decodeExpression - typeMap.put("timestamp", new DomainInfo( - "u_int64_t", // type - "8", // size - "buffer.putLongLong(#)", // encodeExpression - "buffer.getLongLong(#)")); // decodeExpression - } - - - public boolean isQuietFlag() - { - return quietFlag; - } - - public void setQuietFlag(boolean quietFlag) - { - this.quietFlag = quietFlag; - } - - // === Start of methods for Interface LanguageConverter === - - public String prepareClassName(String className) - { - return camelCaseName(className, true); - } - - public String prepareMethodName(String methodName) - { - return camelCaseName(methodName, false); - } - - public String prepareDomainName(String domainName) - { - return camelCaseName(domainName, false); - } - - - public String getGeneratedType(String domainName, AmqpVersion version) - throws AmqpTypeMappingException - { - String domainType = getDomainType(domainName, version); - if (domainType == null) - { - throw new AmqpTypeMappingException("Domain type \"" + domainName + - "\" not found in C++ typemap."); - } - DomainInfo info = typeMap.get(domainType); - if (info == null) - { - throw new AmqpTypeMappingException("Unknown domain: \"" + domainType + "\""); - } - return info.type; - } - - // === Abstract methods from class Generator - C++-specific implementation === - - @Override - protected String prepareFilename(String filenameTemplate, AmqpClass thisClass, AmqpMethod method, - AmqpField field, AmqpVersion version) - { - StringBuffer sb = new StringBuffer(filenameTemplate); - if (thisClass != null) - { - replaceToken(sb, "${CLASS}", thisClass.getName()); - } - if (method != null) - { - replaceToken(sb, "${METHOD}", method.getName()); - } - if (field != null) - { - replaceToken(sb, "${FIELD}", field.getName()); - } - return sb.toString(); - } - - @Override - protected void processModelTemplate(NamedTemplate template) - { - processTemplate(template, null, null, null, null); - } - - @Override - protected void processClassTemplate(NamedTemplate template, AmqpClass thisClass) - { - processTemplate(template, thisClass, null, null, null); - } - - @Override - protected void processMethodTemplate(NamedTemplate template, AmqpClass thisClass, - AmqpMethod method) - { - StringBuffer sb = new StringBuffer(template.getTemplate()); - String filename = prepareFilename(getTemplateFileName(sb), thisClass, method, null, null); - boolean templateProcessedFlag = false; - - // If method is not version consistent, create a namespace for each version - // i.e. copy the bit between the versionNamespaceStartToken and versionNamespaceEndToken - // once for each namespace. - if (method != null) - { - if (!method.isVersionConsistent(getVersionSet())) - { - int namespaceStartIndex = sb.indexOf(versionNamespaceStartToken); - int namespaceEndIndex = sb.indexOf(versionNamespaceEndToken) + - versionNamespaceEndToken.length(); - if (namespaceStartIndex >= 0 && namespaceEndIndex >= 0 && - namespaceStartIndex <= namespaceEndIndex) - { - String namespaceSpan = sb.substring(namespaceStartIndex, namespaceEndIndex) + CR; - sb.delete(namespaceStartIndex, namespaceEndIndex); - for (AmqpVersion v : method.getVersionSet()) - { - StringBuffer nssb = new StringBuffer(namespaceSpan); - processTemplate(nssb, thisClass, method, null, template.getName(), v); - sb.insert(namespaceStartIndex, nssb); - } - // Process all tokens *not* within the namespace span prior to inserting namespaces - processTemplate(sb, thisClass, method, null, template.getName(), null); - } - templateProcessedFlag = true; - } - } - // Remove any remaining namespace tags - int nsTokenIndex = sb.indexOf(versionNamespaceStartToken); - while (nsTokenIndex > 0) - { - sb.delete(nsTokenIndex, nsTokenIndex + versionNamespaceStartToken.length()); - nsTokenIndex = sb.indexOf(versionNamespaceStartToken); - } - nsTokenIndex = sb.indexOf(versionNamespaceEndToken); - while (nsTokenIndex > 0) - { - sb.delete(nsTokenIndex, nsTokenIndex + versionNamespaceEndToken.length()); - nsTokenIndex = sb.indexOf(versionNamespaceEndToken); - } - - if (!templateProcessedFlag) - { - processTemplate(sb, thisClass, method, null, template.getName(), null); - } - writeTargetFile(sb, new File(getOutputDirectory() + Utils.FILE_SEPARATOR + filename)); - generatedFileCounter++; - } - - @Override - protected void processTemplate(NamedTemplate template, AmqpClass thisClass, AmqpMethod method, - AmqpField field, AmqpVersion version) - { - StringBuffer sb = new StringBuffer(template.getTemplate()); - String filename = prepareFilename(getTemplateFileName(sb), thisClass, method, field, version); - processTemplate(sb, thisClass, method, field, template.getName(), null); - writeTargetFile(sb, new File(getOutputDirectory() + Utils.FILE_SEPARATOR + filename)); - generatedFileCounter++; - } - - protected void processTemplate(StringBuffer sb, AmqpClass thisClass, AmqpMethod method, - AmqpField field, String templateFileName, AmqpVersion version) - { - try - { - processAllLists(sb, thisClass, method, version); - } - catch (AmqpTemplateException e) - { - System.out.println("ERROR: " + templateFileName + ": " + e.getMessage()); - } - try - { - processAllTokens(sb, thisClass, method, field, version); - } - catch (AmqpTemplateException e) - { - System.out.println("ERROR: " + templateFileName + ": " + e.getMessage()); - } - } - - @Override - protected String processToken(String token, AmqpClass thisClass, AmqpMethod method, AmqpField field, - AmqpVersion version) - { - if (token.compareTo("${GENERATOR}") == 0) - { - return GENERATOR_INFO; - } - if (token.compareTo("${CLASS}") == 0 && thisClass != null) - { - return thisClass.getName(); - } - if (token.compareTo("${CLASS_ID_INIT}") == 0 && thisClass != null) - { - if (version == null) - { - return String.valueOf(thisClass.getIndexMap().firstKey()); - } - return getIndex(thisClass.getIndexMap(), version); - } - if (token.compareTo("${METHOD}") == 0 && method != null) - { - return method.getName(); - } - if (token.compareTo("${METHOD_ID_INIT}") == 0 && method != null) - { - if (version == null) - { - return String.valueOf(method.getIndexMap().firstKey()); - } - return getIndex(method.getIndexMap(), version); - } - if (token.compareTo("${FIELD}") == 0 && field != null) - { - return field.getName(); - } - if (token.compareTo(versionNamespaceStartToken) == 0 && version != null) - { - return "namespace " + version.namespace() + CR + "{"; - } - if (token.compareTo(versionNamespaceEndToken) == 0 && version != null) - { - return "} // namespace " + version.namespace(); - } - if (token.compareTo("${mb_constructor_with_initializers}") == 0) - { - return generateConstructor(thisClass, method, version, 4, 4); - } - if (token.compareTo("${mb_server_operation_invoke}") == 0) - { - return generateServerOperationsInvoke(thisClass, method, version, 4, 4); - } - if (token.compareTo("${mb_buffer_param}") == 0) - { - return method.getFieldMap().size() > 0 ? " buffer" : ""; - } - if (token.compareTo("${hv_latest_major}") == 0) - { - return String.valueOf(getVersionSet().last().getMajor()); - } - if (token.compareTo("${hv_latest_minor}") == 0) - { - return String.valueOf(getVersionSet().last().getMinor()); - } - - throw new AmqpTemplateException("Template token " + token + " unknown."); - } - - @Override - protected void processClassList(StringBuffer sb, int listMarkerStartIndex, int listMarkerEndIndex, - AmqpModel model, AmqpVersion version) - { - String codeSnippet; - int lend = sb.indexOf(CR, listMarkerStartIndex) + 1; // Include cr at end of line - String tline = sb.substring(listMarkerEndIndex, lend); // Line excluding line marker, including cr - int tokxStart = tline.indexOf('$'); - String token = tline.substring(tokxStart).trim(); - sb.delete(listMarkerStartIndex, lend); - - // ClientOperations.h - if (token.compareTo("${coh_method_handler_get_method}") == 0) - { - codeSnippet = generateOpsMethodHandlerGetMethods(model, false, 4); - } - else if (token.compareTo("${coh_inner_class}") == 0) - { - codeSnippet = generateOpsInnerClasses(model, false, 4, 4); - } - - // ServerOperations.h - else if (token.compareTo("${soh_method_handler_get_method}") == 0) - { - codeSnippet = generateOpsMethodHandlerGetMethods(model, true, 4); - } - else if (token.compareTo("${soh_inner_class}") == 0) - { - codeSnippet = generateOpsInnerClasses(model, true, 4, 4); - } - - // ClientProxy.h/cpp - else if (token.compareTo("${cph_inner_class_instance}") == 0) - { - codeSnippet = generateProxyInnerClassInstances(model, false, 4); - } - else if (token.compareTo("${cph_inner_class_get_method}") == 0) - { - codeSnippet = generateProxyInnerClassGetMethodDecls(model, false, 4); - } - else if (token.compareTo("${cph_inner_class_defn}") == 0) - { - codeSnippet = generateProxyInnerClassDefinitions(model, false, 4, 4); - } - else if (token.compareTo("${cpc_constructor_initializer}") == 0) - { - codeSnippet = generateProxyConstructorInitializers(model, false, 4); - } - else if (token.compareTo("${cpc_inner_class_get_method}") == 0) - { - codeSnippet = generateProxyInnerClassGetMethodImpls(model, false, 0, 4); - } - else if (token.compareTo("${cpc_inner_class_impl}") == 0) - { - codeSnippet = generateProxyInnerClassImpl(model, false, 0, 4); - } - else if (token.compareTo("${cph_handler_pointer_defn}") == 0) - { - codeSnippet = generateHandlerPointerDefinitions(model, false, 4); - } - else if (token.compareTo("${cph_handler_pointer_get_method}") == 0) - { - codeSnippet = generateHandlerPointerGetMethods(model, false, 4); - } - - // SerrverProxy.h/cpp - else if (token.compareTo("${sph_inner_class_instance}") == 0) - { - codeSnippet = generateProxyInnerClassInstances(model, true, 4); - } - else if (token.compareTo("${sph_inner_class_get_method}") == 0) - { - codeSnippet = generateProxyInnerClassGetMethodDecls(model, true, 4); - } - else if (token.compareTo("${sph_inner_class_defn}") == 0) - { - codeSnippet = generateProxyInnerClassDefinitions(model, true, 4, 4); - } - else if (token.compareTo("${spc_constructor_initializer}") == 0) - { - codeSnippet = generateProxyConstructorInitializers(model, true, 4); - } - else if (token.compareTo("${spc_inner_class_get_method}") == 0) - { - codeSnippet = generateProxyInnerClassGetMethodImpls(model, true, 0, 4); - } - else if (token.compareTo("${spc_inner_class_impl}") == 0) - { - codeSnippet = generateProxyInnerClassImpl(model, true, 0, 4); - } - else if (token.compareTo("${sph_handler_pointer_defn}") == 0) - { - codeSnippet = generateHandlerPointerDefinitions(model, true, 4); - } - else if (token.compareTo("${sph_handler_pointer_get_method}") == 0) - { - codeSnippet = generateHandlerPointerGetMethods(model, true, 4); - } - - // amqp_methods.h/cpp - else if (token.compareTo("${mh_method_body_class_indlude}") == 0) - { - codeSnippet = generateMethodBodyIncludeList(model, 0); - } - else if (token.compareTo("${mh_method_body_class_instance}") == 0) - { - codeSnippet = generateMethodBodyInstances(model, 0); - } - else if (token.compareTo("${mc_create_method_body_map_entry}") == 0) - { - codeSnippet = generateMethodBodyMapEntry(model, 4); - } - - else // Oops! - { - throw new AmqpTemplateException("Template token \"" + token + "\" unknown."); - } - sb.insert(listMarkerStartIndex, codeSnippet); - } - - @Override - protected void processMethodList(StringBuffer sb, int listMarkerStartIndex, int listMarkerEndIndex, - AmqpClass thisClass) - { - String codeSnippet; - int lend = sb.indexOf(CR, listMarkerStartIndex) + 1; // Include cr at end of line - String tline = sb.substring(listMarkerEndIndex, lend); // Line excluding line marker, including cr - int tokxStart = tline.indexOf('$'); - String token = tline.substring(tokxStart).trim(); - sb.delete(listMarkerStartIndex, lend); - - if (token.compareTo("${cpc_method_body_include}") == 0) - { - codeSnippet = generateMethodBodyIncludes(thisClass, 0); - } - else if (token.compareTo("${spc_method_body_include}") == 0) - { - codeSnippet = generateMethodBodyIncludes(thisClass, 0); - } - else if (token.compareTo("${mc_method_body_include}") == 0) - { - codeSnippet = generateMethodBodyIncludes(thisClass, 0); - } - - else // Oops! - { - throw new AmqpTemplateException("Template token " + token + " unknown."); - } - sb.insert(listMarkerStartIndex, codeSnippet); - } - - @Override - protected void processFieldList(StringBuffer sb, int listMarkerStartIndex, int listMarkerEndIndex, - AmqpFieldMap fieldMap, AmqpVersion version) - { - String codeSnippet; - int lend = sb.indexOf(CR, listMarkerStartIndex) + 1; // Include cr at end of line - String tline = sb.substring(listMarkerEndIndex, lend); // Line excluding line marker, including cr - int tokxStart = tline.indexOf('$'); - String token = tline.substring(tokxStart).trim(); - sb.delete(listMarkerStartIndex, lend); - - if (token.compareTo("${mb_field_declaration}") == 0) - { - codeSnippet = generateFieldDeclarations(fieldMap, version, 4); - } - else if (token.compareTo("${mb_field_get_method}") == 0) - { - codeSnippet = generateFieldGetMethods(fieldMap, version, 4); - } - else if (token.compareTo("${mb_field_print}") == 0) - { - codeSnippet = generatePrintMethodContents(fieldMap, version, 8); - } - else if (token.compareTo("${mb_body_size}") == 0) - { - codeSnippet = generateBodySizeMethodContents(fieldMap, version, 8); - } - else if (token.compareTo("${mb_encode}") == 0) - { - codeSnippet = generateEncodeMethodContents(fieldMap, version, 8); - } - else if (token.compareTo("${mb_decode}") == 0) - { - codeSnippet = generateDecodeMethodContents(fieldMap, version, 8); - } - - else // Oops! - { - throw new AmqpTemplateException("Template token " + token + " unknown."); - } - sb.insert(listMarkerStartIndex, codeSnippet); - } - - @Override - protected void processConstantList(StringBuffer sb, int listMarkerStartIndex, int listMarkerEndIndex, - AmqpConstantSet constantSet) - { - String codeSnippet; - int lend = sb.indexOf(CR, listMarkerStartIndex) + 1; // Include cr at end of line - String tline = sb.substring(listMarkerEndIndex, lend); // Line excluding line marker, including cr - int tokxStart = tline.indexOf('$'); - String token = tline.substring(tokxStart).trim(); - sb.delete(listMarkerStartIndex, lend); - - if (token.compareTo("${ch_get_value_method}") == 0) - { - codeSnippet = generateConstantGetMethods(constantSet, 4, 4); - } - - else // Oops! - { - throw new AmqpTemplateException("Template token " + token + " unknown."); - } - sb.insert(listMarkerStartIndex, codeSnippet); - } - - // === Protected and private helper functions unique to C++ implementation === - - // Methods for generation of code snippets for AMQP_Constants.h file - - protected String generateConstantGetMethods(AmqpConstantSet constantSet, - int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - for (AmqpConstant thisConstant : constantSet.getContstants()) - { - if (thisConstant.isVersionConsistent(getVersionSet())) - { - // return a constant - String value = thisConstant.firstKey(); - sb.append(indent + "static const char* " + thisConstant.getName() + "() { return \"" + - thisConstant.firstKey() + "\"; }" + CR); - if (Utils.containsOnlyDigits(value)) - { - sb.append(indent + "static int " + thisConstant.getName() + "AsInt() { return " + - thisConstant.firstKey() + "; }" + CR); - } - if (Utils.containsOnlyDigitsAndDecimal(value)) - { - sb.append(indent + "static double " + thisConstant.getName() + "AsDouble() { return (double)" + - thisConstant.firstKey() + "; }" + CR); - } - sb.append(CR); - } - else - { - // Return version-specific constant - sb.append(generateVersionDependentGet(thisConstant, "const char*", "", "\"", "\"", indentSize, tabSize)); - sb.append(generateVersionDependentGet(thisConstant, "int", "AsInt", "", "", indentSize, tabSize)); - sb.append(generateVersionDependentGet(thisConstant, "double", "AsDouble", "(double)", "", indentSize, tabSize)); - sb.append(CR); - } - } - return sb.toString(); - } - - protected String generateVersionDependentGet(AmqpConstant constant, String methodReturnType, - String methodNameSuffix, String returnPrefix, String returnPostfix, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - sb.append(indent + methodReturnType + " " + constant.getName() + methodNameSuffix + - "() const" + CR); - sb.append(indent + "{" + CR); - boolean first = true; - for (String thisValue : constant.keySet()) - { - AmqpVersionSet versionSet = constant.get(thisValue); - sb.append(indent + tab + (first ? "" : "else ") + "if (" + generateVersionCheck(versionSet) + - ")" + CR); - sb.append(indent + tab + "{" + CR); - if (methodReturnType.compareTo("int") == 0 && !Utils.containsOnlyDigits(thisValue)) - { - sb.append(generateConstantDeclarationException(constant.getName(), methodReturnType, - indentSize + (2 * tabSize), tabSize)); - } - else if (methodReturnType.compareTo("double") == 0 && !Utils.containsOnlyDigitsAndDecimal(thisValue)) - { - sb.append(generateConstantDeclarationException(constant.getName(), methodReturnType, - indentSize + (2 * tabSize), tabSize)); - } - else - { - sb.append(indent + tab + tab + "return " + returnPrefix + thisValue + returnPostfix + ";" + CR); - } - sb.append(indent + tab + "}" + CR); - first = false; - } - sb.append(indent + tab + "else" + CR); - sb.append(indent + tab + "{" + CR); - sb.append(indent + tab + tab + "std::stringstream ss;" + CR); - sb.append(indent + tab + tab + "ss << \"Constant \\\"" + constant.getName() + - "\\\" is undefined for AMQP version \" <<" + CR); - sb.append(indent + tab + tab + tab + "version.toString() << \".\";" + CR); - sb.append(indent + tab + tab + "throw ProtocolVersionException(ss.str());" + CR); - sb.append(indent + tab + "}" + CR); - sb.append(indent + "}" + CR); - return sb.toString(); - } - - protected String generateConstantDeclarationException(String name, String methodReturnType, - int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - sb.append(indent + "std::stringstream ss;" + CR); - sb.append(indent + "ss << \"Constant \\\"" + name + "\\\" cannot be converted to type " + - methodReturnType + " for AMQP version \" <<" + CR); - sb.append(indent + tab + "version.toString() << \".\";" + CR); - sb.append(indent + "throw ProtocolVersionException(ss.str());" + CR); - return sb.toString(); - } - - // Methods used for generation of code snippets for Server/ClientOperations class generation - - protected String generateOpsMethodHandlerGetMethods(AmqpModel model, boolean serverFlag, int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - for (String thisClassName : model.getClassMap().keySet()) - { - AmqpClass thisClass = model.getClassMap().get(thisClassName); - // Only generate for this class if there is at least one method of the - // required chassis (server/client flag). - boolean chassisFoundFlag = false; - for (String thisMethodName : thisClass.getMethodMap().keySet()) - { - AmqpMethod method = thisClass.getMethodMap().get(thisMethodName); - boolean clientChassisFlag = method.getClientMethodFlagMap().isSet(); - boolean serverChassisFlag = method.getServerMethodFlagMap().isSet(); - if ((serverFlag && serverChassisFlag) || (!serverFlag && clientChassisFlag)) - { - chassisFoundFlag = true; - } - } - if (chassisFoundFlag) - { - sb.append(indent + "virtual AMQP_" + (serverFlag ? "Server" : "Client") + "Operations::" + - thisClass.getName() + "Handler* get" + thisClass.getName() + "Handler() = 0;" + CR); - } - } - return sb.toString(); - } - - protected String generateOpsInnerClasses(AmqpModel model, boolean serverFlag, int indentSize, int tabSize) - { - - String proxyClassName = "AMQP_" + (serverFlag ? "Server" : "Client") + "Proxy"; - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - boolean first = true; - for (String thisClassName : model.getClassMap().keySet()) - { - AmqpClass thisClass = model.getClassMap().get(thisClassName); - String handlerClassName = thisClass.getName() + "Handler"; - if (!first) - { - sb.append(CR); - } - sb.append(indent + "// ==================== class " + handlerClassName + - " ====================" + CR); - sb.append(indent + "class " + handlerClassName); - if (thisClass.getVersionSet().size() != getVersionSet().size()) - { - sb.append(" // AMQP Version(s) " + thisClass.getVersionSet() + CR); - } - else - { - sb.append(CR); - } - sb.append(indent + "{" + CR); - sb.append(indent + "private:" + CR); - sb.append(indent + tab + proxyClassName + "* parent;" + CR); - sb.append(CR); - sb.append(indent + tab + "// Constructors and destructors" + CR); - sb.append(CR); - sb.append(indent + "protected:" + CR); - sb.append(indent + tab + handlerClassName + "() {}" + CR); - sb.append(indent + "public:" + CR); - sb.append(indent + tab + handlerClassName + - "(" + proxyClassName + "* _parent) {parent = _parent;}" + CR); - sb.append(indent + tab + "virtual ~" + handlerClassName + "() {}" + CR); - sb.append(CR); - sb.append(indent + tab + "// Protocol methods" + CR); - sb.append(CR); - sb.append(generateInnerClassMethods(thisClass, serverFlag, true, indentSize + tabSize, tabSize)); - sb.append(indent + "}; // class " + handlerClassName + CR); - first = false; - } - return sb.toString(); - } - - protected String generateInnerClassMethods(AmqpClass thisClass, boolean serverFlag, - boolean abstractMethodFlag, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - String outerClassName = "AMQP_" + (serverFlag ? "Server" : "Client") + (abstractMethodFlag ? "Operations" - : "Proxy"); - boolean first = true; - for (String thisMethodName : thisClass.getMethodMap().keySet()) - { - AmqpMethod method = thisClass.getMethodMap().get(thisMethodName); - boolean clientChassisFlag = method.getClientMethodFlagMap().isSet(); - boolean serverChassisFlag = method.getServerMethodFlagMap().isSet(); - if ((serverFlag && serverChassisFlag) || (!serverFlag && clientChassisFlag)) - { - String methodName = parseForReservedWords(method.getName(), outerClassName + "." + thisClass.getName()); - AmqpOverloadedParameterMap overloadededParameterMap = - method.getOverloadedParameterLists(thisClass.getVersionSet(), this); - for (AmqpOrdinalFieldMap thisFieldMap : overloadededParameterMap.keySet()) - { - AmqpVersionSet versionSet = overloadededParameterMap.get(thisFieldMap); - if (!first) - { - sb.append(CR); - } - sb.append(indent + "virtual void " + methodName + "( u_int16_t channel"); - sb.append(generateMethodParameterList(thisFieldMap, indentSize + (5 * tabSize), true, true, true)); - sb.append(" )"); - if (abstractMethodFlag) - { - sb.append(" = 0"); - } - sb.append(";"); - if (versionSet.size() != getVersionSet().size()) - { - sb.append(" // AMQP Version(s) " + versionSet); - } - sb.append(CR); - first = false; - } - } - } - return sb.toString(); - } - - // Methods used for generation of code snippets for Server/ClientProxy class generation - - protected String generateHandlerPointerDefinitions(AmqpModel model, boolean serverFlag, - int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - String outerClassName = "AMQP_" + (serverFlag ? "Server" : "Client") + "Operations"; - for (String thisClassName : model.getClassMap().keySet()) - { - AmqpClass thisClass = model.getClassMap().get(thisClassName); - sb.append(indent + outerClassName + "::" + thisClass.getName() + "Handler* " + - thisClass.getName() + "HandlerPtr;" + CR); - } - return sb.toString(); - } - - protected String generateHandlerPointerGetMethods(AmqpModel model, boolean serverFlag, - int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - String outerClassName = "AMQP_" + (serverFlag ? "Server" : "Client") + "Operations"; - for (String thisClassName : model.getClassMap().keySet()) - { - AmqpClass thisClass = model.getClassMap().get(thisClassName); - sb.append(indent + "virtual inline " + outerClassName + "::" + thisClass.getName() + "Handler* get" + - thisClass.getName() + "Handler() { return &" + Utils.firstLower(thisClass.getName()) + ";}" + CR); - } - return sb.toString(); - } - - protected String generateProxyInnerClassInstances(AmqpModel model, boolean serverFlag, - int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - String outerClassName = "AMQP_" + (serverFlag ? "Server" : "Client") + "Proxy"; - for (String thisClassName : model.getClassMap().keySet()) - { - AmqpClass thisClass = model.getClassMap().get(thisClassName); - String instanceName = parseForReservedWords(Utils.firstLower(thisClass.getName()), outerClassName); - String className = parseForReservedWords(thisClass.getName(), null); - sb.append(indent + className + " " + instanceName + ";"); - if (thisClass.getVersionSet().size() != getVersionSet().size()) - { - sb.append(" // AMQP Version(s) " + thisClass.getVersionSet() + CR); - } - else - { - sb.append(CR); - } - } - return sb.toString(); - } - - protected String generateProxyInnerClassGetMethodDecls(AmqpModel model, boolean serverFlag, - int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - String outerClassName = "AMQP_" + (serverFlag ? "Server" : "Client") + "Proxy"; - for (String thisClassName : model.getClassMap().keySet()) - { - AmqpClass thisClass = model.getClassMap().get(thisClassName); - String className = parseForReservedWords(thisClass.getName(), outerClassName); - sb.append(indent + className + "& get" + className + "();"); - if (thisClass.getVersionSet().size() != getVersionSet().size()) - { - sb.append(" // AMQP Version(s) " + thisClass.getVersionSet() + CR); - } - else - { - sb.append(CR); - } - } - return sb.toString(); - } - - protected String generateProxyInnerClassDefinitions(AmqpModel model, boolean serverFlag, - int indentSize, int tabSize) - { - String proxyClassName = "AMQP_" + (serverFlag ? "Server" : "Client") + "Proxy"; - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - boolean first = true; - for (String thisClassName : model.getClassMap().keySet()) - { - AmqpClass thisClass = model.getClassMap().get(thisClassName); - String className = thisClass.getName(); - String superclassName = "AMQP_" + (serverFlag ? "Server" : "Client") + "Operations::" + - thisClass.getName() + "Handler"; - if (!first) - { - sb.append(CR); - } - sb.append(indent + "// ==================== class " + className + - " ====================" + CR); - sb.append(indent + "class " + className + " : virtual public " + superclassName); - if (thisClass.getVersionSet().size() != getVersionSet().size()) - { - sb.append(" // AMQP Version(s) " + thisClass.getVersionSet() + CR); - } - else - { - sb.append(CR); - } - sb.append(indent + "{" + CR); - sb.append(indent + "private:" + CR); - sb.append(indent + tab + "OutputHandler* out;" + CR); - sb.append(indent + tab + proxyClassName + "* parent;" + CR); - sb.append(CR); - sb.append(indent + "public:" + CR); - sb.append(indent + tab + "// Constructors and destructors" + CR); - sb.append(CR); - sb.append(indent + tab + className + "(OutputHandler* out, " + proxyClassName + "* _parent) : " + CR); - sb.append(indent + tab + tab + "out(out) {parent = _parent;}" + CR); - sb.append(indent + tab + "virtual ~" + className + "() {}" + CR); - sb.append(CR); - sb.append(indent + tab + "// Protocol methods" + CR); - sb.append(CR); - sb.append(generateInnerClassMethods(thisClass, serverFlag, false, indentSize + tabSize, tabSize)); - sb.append(indent + "}; // class " + className + CR); - first = false; - } - return sb.toString(); - } - - protected String generateProxyConstructorInitializers(AmqpModel model, boolean serverFlag, - int indentSize) - { - String outerClassName = "AMQP_" + (serverFlag ? "Server" : "Client") + "Proxy"; - String superclassName = "AMQP_" + (serverFlag ? "Server" : "Client") + "Operations"; - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(indent + superclassName + "(major, minor)," + CR); - sb.append(indent + "version(major, minor)," + CR); - sb.append(indent + "out(out)"); - Iterator<String> cItr = model.getClassMap().keySet().iterator(); - while (cItr.hasNext()) - { - AmqpClass thisClass = model.getClassMap().get(cItr.next()); - String instanceName = parseForReservedWords(Utils.firstLower(thisClass.getName()), outerClassName); - sb.append("," + CR); - sb.append(indent + instanceName + "(out, this)"); - if (!cItr.hasNext()) - { - sb.append(CR); - } - } - return sb.toString(); - } - - protected String generateProxyInnerClassGetMethodImpls(AmqpModel model, boolean serverFlag, - int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - String outerClassName = "AMQP_" + (serverFlag ? "Server" : "Client") + "Proxy"; - Iterator<String> cItr = model.getClassMap().keySet().iterator(); - while (cItr.hasNext()) - { - AmqpClass thisClass = model.getClassMap().get(cItr.next()); - String className = thisClass.getName(); - String instanceName = parseForReservedWords(Utils.firstLower(thisClass.getName()), outerClassName); - sb.append(indent + outerClassName + "::" + className + "& " + - outerClassName + "::get" + className + "()" + CR); - sb.append(indent + "{" + CR); - if (thisClass.getVersionSet().size() != getVersionSet().size()) - { - sb.append(indent + tab + "if (!" + generateVersionCheck(thisClass.getVersionSet()) + ")" + CR); - sb.append(indent + tab + tab + "throw new ProtocolVersionException();" + CR); - } - sb.append(indent + tab + "return " + instanceName + ";" + CR); - sb.append(indent + "}" + CR); - if (cItr.hasNext()) - { - sb.append(CR); - } - } - return sb.toString(); - } - - protected String generateProxyInnerClassImpl(AmqpModel model, boolean serverFlag, - int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - boolean firstClassFlag = true; - for (String thisClassName : model.getClassMap().keySet()) - { - AmqpClass thisClass = model.getClassMap().get(thisClassName); - String className = thisClass.getName(); - if (!firstClassFlag) - { - sb.append(CR); - } - sb.append(indent + "// ==================== class " + className + - " ====================" + CR); - sb.append(generateInnerClassMethodImpls(thisClass, serverFlag, indentSize, tabSize)); - firstClassFlag = false; - } - return sb.toString(); - } - - protected String generateInnerClassMethodImpls(AmqpClass thisClass, boolean serverFlag, - int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - String outerclassName = "AMQP_" + (serverFlag ? "Server" : "Client") + "Proxy"; - boolean first = true; - for (String thisMethodName : thisClass.getMethodMap().keySet()) - { - AmqpMethod method = thisClass.getMethodMap().get(thisMethodName); - String methodBodyClassName = thisClass.getName() + Utils.firstUpper(method.getName()) + "Body"; - boolean clientChassisFlag = method.getClientMethodFlagMap().isSet(); - boolean serverChassisFlag = method.getServerMethodFlagMap().isSet(); - boolean versionConsistentFlag = method.isVersionConsistent(getVersionSet()); - if ((serverFlag && serverChassisFlag) || (!serverFlag && clientChassisFlag)) - { - String methodName = parseForReservedWords(method.getName(), outerclassName + "." + thisClass.getName()); - AmqpOverloadedParameterMap overloadededParameterMap = - method.getOverloadedParameterLists(thisClass.getVersionSet(), this); - for (AmqpOrdinalFieldMap thisFieldMap : overloadededParameterMap.keySet()) - { - AmqpVersionSet versionSet = overloadededParameterMap.get(thisFieldMap); - if (!first) - { - sb.append(CR); - } - sb.append(indent + "void " + outerclassName + "::" + thisClass.getName() + "::" + - methodName + "( u_int16_t channel"); - sb.append(generateMethodParameterList(thisFieldMap, indentSize + (5 * tabSize), true, true, true)); - sb.append(" )"); - if (versionSet.size() != getVersionSet().size()) - { - sb.append(" // AMQP Version(s) " + versionSet); - } - sb.append(CR); - sb.append(indent + "{" + CR); - sb.append(generateMethodBodyCallContext(thisFieldMap, outerclassName, methodBodyClassName, - versionConsistentFlag, versionSet, indentSize + tabSize, tabSize)); - sb.append(indent + "}" + CR); - sb.append(CR); - first = false; - } - } - } - return sb.toString(); - } - - protected String generateMethodBodyCallContext(AmqpOrdinalFieldMap fieldMap, String outerclassName, - String methodBodyClassName, boolean versionConsistentFlag, AmqpVersionSet versionSet, - int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - if (versionConsistentFlag) - { - sb.append(generateMethodBodyCall(fieldMap, methodBodyClassName, null, indentSize, tabSize)); - } - else - { - boolean firstOverloadedMethodFlag = true; - for (AmqpVersion thisVersion : versionSet) - { - sb.append(indent); - if (!firstOverloadedMethodFlag) - { - sb.append("else "); - } - sb.append("if (" + generateVersionCheck(thisVersion) + ")" + CR); - sb.append(indent + "{" + CR); - sb.append(generateMethodBodyCall(fieldMap, methodBodyClassName, thisVersion, - indentSize + tabSize, tabSize)); - sb.append(indent + "}" + CR); - firstOverloadedMethodFlag = false; - } - sb.append(indent + "else" + CR); - sb.append(indent + "{" + CR); - sb.append(indent + tab + "std::stringstream ss;" + CR); - sb.append(indent + tab + "ss << \"Call to " + outerclassName + "::" + methodBodyClassName + - "(u_int16_t" + generateMethodParameterList(fieldMap, 0, true, true, false) + ")\"" + CR); - sb.append(indent + tab + tab + "<< \" is invalid for AMQP version \" << version.toString() << \".\";" + CR); - sb.append(indent + tab + "throw new ProtocolVersionException(ss.str());" + CR); - sb.append(indent + "}" + CR); - } - return sb.toString(); - } - - protected String generateMethodBodyCall(AmqpOrdinalFieldMap fieldMap, String methodBodyClassName, - AmqpVersion version, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - String namespace = version != null ? version.namespace() + "::" : ""; - StringBuffer sb = new StringBuffer(indent + "out->send( new AMQFrame(parent->getProtocolVersion(), channel," + CR); - sb.append(indent + tab + "new " + namespace + methodBodyClassName + "( parent->getProtocolVersion()"); - sb.append(generateMethodParameterList(fieldMap, indentSize + (5 * tabSize), true, false, true)); - sb.append(" )));" + CR); - return sb.toString(); - } - - protected String generateMethodBodyIncludes(AmqpClass thisClass, int indentSize) - { - StringBuffer sb = new StringBuffer(); - if (thisClass != null) - { - sb.append(generateClassMethodBodyInclude(thisClass, indentSize)); - } - else - { - for (String thisClassName : getModel().getClassMap().keySet()) - { - thisClass = getModel().getClassMap().get(thisClassName); - sb.append(generateClassMethodBodyInclude(thisClass, indentSize)); - } - } - return sb.toString(); - } - - protected String generateClassMethodBodyInclude(AmqpClass thisClass, int indentSize) - { - StringBuffer sb = new StringBuffer(); - String indent = Utils.createSpaces(indentSize); - for (String thisMethodName : thisClass.getMethodMap().keySet()) - { - AmqpMethod method = thisClass.getMethodMap().get(thisMethodName); - sb.append(indent + "#include <" + thisClass.getName() + - Utils.firstUpper(method.getName()) + "Body.h>" + CR); - } - return sb.toString(); - } - - // Methods used for generation of code snippets for MethodBody class generation - - protected String getIndex(AmqpOrdinalVersionMap indexMap, AmqpVersion version) - { - for (Integer thisIndex : indexMap.keySet()) - { - AmqpVersionSet versionSet = indexMap.get(thisIndex); - if (versionSet.contains(version)) - { - return String.valueOf(thisIndex); - } - } - throw new AmqpTemplateException("Unable to find index for version " + version); - } - - protected String generateFieldDeclarations(AmqpFieldMap fieldMap, AmqpVersion version, int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - - if (version == null) - { - version = getVersionSet().first(); - } - AmqpOrdinalFieldMap ordinalFieldMap = fieldMap.getMapForVersion(version, true, this); - for (Integer thisOrdinal : ordinalFieldMap.keySet()) - { - String[] fieldDomainPair = ordinalFieldMap.get(thisOrdinal); - sb.append(indent + fieldDomainPair[FIELD_CODE_TYPE] + " " + fieldDomainPair[FIELD_NAME] + ";" + CR); - } - return sb.toString(); - } - - protected String generateFieldGetMethods(AmqpFieldMap fieldMap, AmqpVersion version, int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - - if (version == null) - { - version = getVersionSet().first(); - } - AmqpOrdinalFieldMap ordinalFieldMap = fieldMap.getMapForVersion(version, true, this); - for (Integer thisOrdinal : ordinalFieldMap.keySet()) - { - String[] fieldDomainPair = ordinalFieldMap.get(thisOrdinal); - sb.append(indent + "inline " + setRef(fieldDomainPair[FIELD_CODE_TYPE]) + " get" + - Utils.firstUpper(fieldDomainPair[FIELD_NAME]) + "() { return " + - fieldDomainPair[FIELD_NAME] + "; }" + CR); - } - return sb.toString(); - } - - protected String generatePrintMethodContents(AmqpFieldMap fieldMap, AmqpVersion version, int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - - if (version == null) - { - version = getVersionSet().first(); - } - AmqpOrdinalFieldMap ordinalFieldMap = fieldMap.getMapForVersion(version, true, this); - boolean firstFlag = true; - for (Integer thisOrdinal : ordinalFieldMap.keySet()) - { - String[] fieldDomainPair = ordinalFieldMap.get(thisOrdinal); - String cast = fieldDomainPair[FIELD_CODE_TYPE].compareTo("u_int8_t") == 0 ? "(int)" : ""; - sb.append(indent + "out << \""); - if (!firstFlag) - { - sb.append("; "); - } - sb.append(fieldDomainPair[FIELD_NAME] + "=\" << " + cast + fieldDomainPair[FIELD_NAME] + ";" + CR); - firstFlag = false; - } - return sb.toString(); - } - - protected String generateBodySizeMethodContents(AmqpFieldMap fieldMap, AmqpVersion version, - int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - ArrayList<String> bitFieldList = new ArrayList<String>(); - AmqpOrdinalFieldMap ordinalFieldMap = fieldMap.getMapForVersion(version, false, this); - Iterator<Integer> oItr = ordinalFieldMap.keySet().iterator(); - int ordinal = 0; - while (oItr.hasNext()) - { - ordinal = oItr.next(); - String[] fieldDomainPair = ordinalFieldMap.get(ordinal); - AmqpVersion thisVersion = version == null ? getVersionSet().first() : version; - String domainType = getDomainType(fieldDomainPair[FIELD_CODE_TYPE], thisVersion); - - // Defer bit types by adding them to an array. When the first subsequent non-bit - // type is encountered, then handle the bits. This allows consecutive bits to be - // placed into the same byte(s) - 8 bits to the byte. - if (domainType.compareTo("bit") == 0) - { - bitFieldList.add(fieldDomainPair[FIELD_NAME]); - } - else - { - if (bitFieldList.size() > 0) // Handle accumulated bit types (if any) - { - sb.append(generateBitArrayBodySizeMethodContents(bitFieldList, ordinal, indentSize)); - } - sb.append(indent + "size += " + - typeMap.get(domainType).size.replaceAll("#", fieldDomainPair[FIELD_NAME]) + - "; /* " + fieldDomainPair[FIELD_NAME] + ": " + - domainType + " */" + CR); - } - } - if (bitFieldList.size() > 0) // Handle any remaining accumulated bit types - { - sb.append(generateBitArrayBodySizeMethodContents(bitFieldList, ordinal, indentSize)); - } - return sb.toString(); - } - - protected String generateBitArrayBodySizeMethodContents(ArrayList<String> bitFieldList, - int ordinal, int indentSize) - { - int numBytes = ((bitFieldList.size() - 1) / 8) + 1; - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - String comment = bitFieldList.size() == 1 ? - bitFieldList.get(0) + ": bit" : - "Combinded bits: " + bitFieldList; - sb.append(indent + "size += " + - typeMap.get("bit").size.replaceAll("~", String.valueOf(numBytes)) + - "; /* " + comment + " */" + CR); - bitFieldList.clear(); - return sb.toString(); - } - - protected String generateEncodeMethodContents(AmqpFieldMap fieldMap, AmqpVersion version, - int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - ArrayList<String> bitFieldList = new ArrayList<String>(); - AmqpOrdinalFieldMap ordinalFieldMap = fieldMap.getMapForVersion(version, false, this); - Iterator<Integer> oItr = ordinalFieldMap.keySet().iterator(); - int ordinal = 0; - while (oItr.hasNext()) - { - ordinal = oItr.next(); - String[] fieldDomainPair = ordinalFieldMap.get(ordinal); - AmqpVersion thisVersion = version == null ? getVersionSet().first() : version; - String domainType = getDomainType(fieldDomainPair[FIELD_CODE_TYPE], thisVersion); - - // Defer bit types by adding them to an array. When the first subsequent non-bit - // type is encountered, then handle the bits. This allows consecutive bits to be - // placed into the same byte(s) - 8 bits to the byte. - if (domainType.compareTo("bit") == 0) - { - bitFieldList.add(fieldDomainPair[FIELD_NAME]); - } - else - { - if (bitFieldList.size() > 0) // Handle accumulated bit types (if any) - { - sb.append(generateBitEncodeMethodContents(bitFieldList, ordinal, indentSize)); - } - sb.append(indent + - typeMap.get(domainType).encodeExpression.replaceAll("#", fieldDomainPair[FIELD_NAME]) + - "; /* " + fieldDomainPair[FIELD_NAME] + ": " + domainType + " */" + CR); - } - } - if (bitFieldList.size() > 0) // Handle any remaining accumulated bit types - { - sb.append(generateBitEncodeMethodContents(bitFieldList, ordinal, indentSize)); - } - - return sb.toString(); - } - - protected String generateBitEncodeMethodContents(ArrayList<String> bitFieldList, int ordinal, - int indentSize) - { - int numBytes = ((bitFieldList.size() - 1) / 8) + 1; - String indent = Utils.createSpaces(indentSize); - String bitArrayName = "flags_" + ordinal; - StringBuffer sb = new StringBuffer(indent + "u_int8_t " + bitArrayName + - "[" + numBytes + "] = {0};" + - (numBytes != 1 ? " /* All array elements will be initialized to 0 */" : "") + - CR); - for (int i = 0; i < bitFieldList.size(); i++) - { - int bitIndex = i % 8; - int byteIndex = i / 8; - sb.append(indent + bitArrayName + "[" + byteIndex + "] |= " + bitFieldList.get(i) + - " << " + bitIndex + "; /* " + bitFieldList.get(i) + ": bit */" + CR); - } - for (int i = 0; i < numBytes; i++) - { - sb.append(indent + "buffer.putOctet(" + bitArrayName + "[" + i + "]);" + CR); - } - bitFieldList.clear(); - return sb.toString(); - } - - protected String generateDecodeMethodContents(AmqpFieldMap fieldMap, AmqpVersion version, - int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - ArrayList<String> bitFieldList = new ArrayList<String>(); - AmqpOrdinalFieldMap ordinalFieldMap = fieldMap.getMapForVersion(version, false, this); - Iterator<Integer> oItr = ordinalFieldMap.keySet().iterator(); - int ordinal = 0; - while (oItr.hasNext()) - { - ordinal = oItr.next(); - String[] fieldDomainPair = ordinalFieldMap.get(ordinal); - AmqpVersion thisVersion = version == null ? getVersionSet().first() : version; - String domainType = getDomainType(fieldDomainPair[FIELD_CODE_TYPE], thisVersion); - - // Defer bit types by adding them to an array. When the first subsequent non-bit - // type is encountered, then handle the bits. This allows consecutive bits to be - // placed into the same byte(s) - 8 bits to the byte. - if (domainType.compareTo("bit") == 0) - { - bitFieldList.add(fieldDomainPair[FIELD_NAME]); - } - else - { - if (bitFieldList.size() > 0) // Handle accumulated bit types (if any) - { - sb.append(generateBitDecodeMethodContents(bitFieldList, ordinal, indentSize)); - } - sb.append(indent + - typeMap.get(domainType).decodeExpression.replaceAll("#", fieldDomainPair[FIELD_NAME]) + - "; /* " + fieldDomainPair[FIELD_NAME] + ": " + domainType + " */" + CR); - } - } - if (bitFieldList.size() > 0) // Handle any remaining accumulated bit types - { - sb.append(generateBitDecodeMethodContents(bitFieldList, ordinal, indentSize)); - } - - return sb.toString(); - } - - protected String generateBitDecodeMethodContents(ArrayList<String> bitFieldList, int ordinal, - int indentSize) - { - int numBytes = ((bitFieldList.size() - 1) / 8) + 1; - String indent = Utils.createSpaces(indentSize); - String bitArrayName = "flags_" + ordinal; - StringBuffer sb = new StringBuffer(indent + "u_int8_t " + bitArrayName + - "[" + numBytes + "];" + CR); - for (int i = 0; i < numBytes; i++) - { - sb.append(indent + bitArrayName + "[" + i + "] = buffer.getOctet();" + CR); - } - for (int i = 0; i < bitFieldList.size(); i++) - { - int bitIndex = i % 8; - int byteIndex = i / 8; - sb.append(indent + bitFieldList.get(i) + " = (1 << " + bitIndex + ") & " + - bitArrayName + "[" + byteIndex + "]; /* " + bitFieldList.get(i) + - ": bit */" + CR); - } - bitFieldList.clear(); - return sb.toString(); - } - - protected String generateFieldList(AmqpFieldMap fieldMap, AmqpVersion version, boolean defineFlag, - boolean initializerFlag, int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - AmqpOrdinalFieldMap ordinalFieldMap = fieldMap.getMapForVersion(version, true, this); - Iterator<Integer> oItr = ordinalFieldMap.keySet().iterator(); - while (oItr.hasNext()) - { - int ordinal = oItr.next(); - String[] fieldDomainPair = ordinalFieldMap.get(ordinal); - sb.append(indent + (defineFlag ? setRef(fieldDomainPair[FIELD_CODE_TYPE]) + " " : "") + - fieldDomainPair[FIELD_NAME] + (initializerFlag ? "(" + fieldDomainPair[FIELD_NAME] + ")" : "") + - (oItr.hasNext() ? "," : "") + CR); - } - return sb.toString(); - } - - protected String generateMethodParameterList(AmqpOrdinalFieldMap fieldMap, int indentSize, - boolean leadingCommaFlag, boolean fieldTypeFlag, boolean fieldNameFlag) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - boolean first = true; - Iterator<Integer> pItr = fieldMap.keySet().iterator(); - while (pItr.hasNext()) - { - String[] field = fieldMap.get(pItr.next()); - if (first && leadingCommaFlag) - { - sb.append("," + (fieldNameFlag ? CR : " ")); - } - if (!first || leadingCommaFlag) - { - sb.append(indent); - } - sb.append( - (fieldTypeFlag ? setRef(field[FIELD_CODE_TYPE]) : "") + - (fieldNameFlag ? " " + field[FIELD_NAME] : "") + - (pItr.hasNext() ? "," + (fieldNameFlag ? CR : " ") : "")); - first = false; - } - return sb.toString(); - } - - protected String generateConstructor(AmqpClass thisClass, AmqpMethod method, - AmqpVersion version, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - if (method.getFieldMap().size() > 0) - { - sb.append(indent + thisClass.getName() + Utils.firstUpper(method.getName()) + "Body(ProtocolVersion& version," + CR); - sb.append(generateFieldList(method.getFieldMap(), version, true, false, 8)); - sb.append(indent + tab + ") :" + CR); - sb.append(indent + tab + "AMQMethodBody(version)," + CR); - sb.append(generateFieldList(method.getFieldMap(), version, false, true, 8)); - sb.append(indent + "{ }" + CR); - } - return sb.toString(); - } - - protected String generateServerOperationsInvoke(AmqpClass thisClass, AmqpMethod method, - AmqpVersion version, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - - if (method.getServerMethodFlagMap().size() > 0) // At least one AMQP version defines this method as a server method - { - Iterator<Boolean> bItr = method.getServerMethodFlagMap().keySet().iterator(); - while (bItr.hasNext()) - { - if (bItr.next()) // This is a server operation - { - boolean fieldMapNotEmptyFlag = method.getFieldMap().size() > 0; - sb.append(indent + "inline void invoke(AMQP_ServerOperations& target, u_int16_t channel)" + CR); - sb.append(indent + "{" + CR); - sb.append(indent + tab + "target.get" + thisClass.getName() + "Handler()->" + - parseForReservedWords(Utils.firstLower(method.getName()), - thisClass.getName() + Utils.firstUpper(method.getName()) + "Body.invoke()") + "(channel"); - if (fieldMapNotEmptyFlag) - { - sb.append("," + CR); - sb.append(generateFieldList(method.getFieldMap(), version, false, false, indentSize + 4 * tabSize)); - sb.append(indent + tab + tab + tab + tab); - } - sb.append(");" + CR); - sb.append(indent + "}" + CR); - } - } - } - return sb.toString(); - } - - // Methods for generation of code snippets for amqp_methods.h/cpp files - - protected String generateMethodBodyIncludeList(AmqpModel model, int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - - for (String thisClassName : model.getClassMap().keySet()) - { - AmqpClass thisClass = model.getClassMap().get(thisClassName); - for (String thisMethodName : thisClass.getMethodMap().keySet()) - { - AmqpMethod method = thisClass.getMethodMap().get(thisMethodName); - sb.append(indent + "#include \"" + thisClass.getName() + Utils.firstUpper(method.getName()) + "Body.h\"" + CR); - } - } - - return sb.toString(); - } - - protected String generateMethodBodyInstances(AmqpModel model, int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - - for (String thisClassName : model.getClassMap().keySet()) - { - AmqpClass thisClass = model.getClassMap().get(thisClassName); - for (String thisMethodName : thisClass.getMethodMap().keySet()) - { - AmqpMethod method = thisClass.getMethodMap().get(thisMethodName); - sb.append(indent + "const " + thisClass.getName() + Utils.firstUpper(method.getName()) + "Body " + - Utils.firstLower(thisClass.getName()) + "_" + method.getName() + ";" + CR); - } - } - - return sb.toString(); - } - - protected String generateMethodBodyMapEntry(AmqpModel model, int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - - for (AmqpVersion version : getVersionSet()) - { - for (String thisClassName : model.getClassMap().keySet()) - { - AmqpClass thisClass = model.getClassMap().get(thisClassName); - for (String thisMethodName : thisClass.getMethodMap().keySet()) - { - AmqpMethod method = thisClass.getMethodMap().get(thisMethodName); - String namespace = method.isVersionConsistent(getVersionSet()) ? "" : version.namespace() + "::"; - try - { - int classOrdinal = thisClass.getIndexMap().getOrdinal(version); - int methodOrdinal = method.getIndexMap().getOrdinal(version); - String methodModyClassName = namespace + thisClass.getName() + Utils.firstUpper(method.getName()) + "Body"; - sb.append(indent + "insert(std::make_pair(createMapKey(" + classOrdinal + ", " + - methodOrdinal + ", " + version.getMajor() + ", " + version.getMinor() + - "), &createMethodBodyFn<" + methodModyClassName + ">));" + CR); - } - catch (AmqpTypeMappingException e) - { - } // ignore - } - } - } - - return sb.toString(); - } - - // Helper functions - - private String generateVersionCheck(AmqpVersion version) - { - return "version.equals(" + version.getMajor() + ", " + version.getMinor() + ")"; - } - - private String generateVersionCheck(AmqpVersionSet versionSet) - { - StringBuffer sb = new StringBuffer(); - for (AmqpVersion v : versionSet) - { - if (!v.equals(versionSet.first())) - { - sb.append(" || "); - } - if (versionSet.size() > 1) - { - sb.append("("); - } - sb.append("version.equals(" + v.getMajor() + ", " + v.getMinor() + ")"); - if (versionSet.size() > 1) - { - sb.append(")"); - } - } - return sb.toString(); - } - - private String parseForReservedWords(String name, String context) - { - for (String cppReservedWord : cppReservedWords) - { - if (name.compareTo(cppReservedWord) == 0) - { - if (!quietFlag) - { - System.out.println("WARNING: " + (context == null ? "" : context + ": ") + - "Found XML method \"" + name + "\", which is a C++ reserved word. " + - "Changing generated name to \"" + name + "_\"."); - } - return name + "_"; - } - } - - for (String cppCommonDefine : cppCommonDefines) - { - if (name.compareTo(cppCommonDefine) == 0) - { - if (!quietFlag) - { - System.out.println("WARNING: " + (context == null ? "" : context + ": ") + - "Found XML method \"" + name + "\", which may clash with commonly used defines within C++. " + - "Changing generated name to \"" + name + "_\"."); - } - return name + "_"; - } - } - - return name; - } - - private String setRef(String codeType) - { - if (codeType.compareTo("string") == 0 || - codeType.compareTo("FieldTable") == 0) - { - return "const " + codeType + "&"; - } - return codeType; - } - - private String camelCaseName(String name, boolean upperFirstFlag) - { - StringBuffer ccn = new StringBuffer(); - String[] toks = name.split("[-_.\\ ]"); - for (int i = 0; i < toks.length; i++) - { - StringBuffer b = new StringBuffer(toks[i]); - if (upperFirstFlag || i > 0) - { - b.setCharAt(0, Character.toUpperCase(toks[i].charAt(0))); - } - ccn.append(b); - } - return ccn.toString(); - } - - public static Factory<CppGenerator> _factoryInstance = new Factory<CppGenerator>() - { - - public CppGenerator newInstance() - { - return new CppGenerator(); - } - }; - - public static Factory<CppGenerator> getFactory() - { - return _factoryInstance; - } - - void processModelTemplate(NamedTemplate template, AmqpVersion version) - { - //To change body of implemented methods use File | Settings | File Templates. - } - public String getNativeType(String type) - { - throw new UnsupportedOperationException(); - } - - public String getEncodingType(String type) - { - throw new UnsupportedOperationException(); - } - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/DotnetGenerator.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/DotnetGenerator.java deleted file mode 100644 index 9fc81dd428..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/DotnetGenerator.java +++ /dev/null @@ -1,382 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -package org.apache.qpid.gentools; - -import java.io.File; -import java.util.TreeMap; - -public class DotnetGenerator extends Generator -{ - private class DomainInfo - { - public String type; - public String size; - public String encodeExpression; - public String decodeExpression; - - public DomainInfo(String domain, String size, String encodeExpression, String decodeExpression) - { - this.type = domain; - this.size = size; - this.encodeExpression = encodeExpression; - this.decodeExpression = decodeExpression; - } - } - - private static TreeMap<String, DomainInfo> typeMap = new TreeMap<String, DomainInfo>(); - - public String getNativeType(String type) - { - throw new UnsupportedOperationException(); - } - - public String getEncodingType(String type) - { - throw new UnsupportedOperationException(); - } - - public DotnetGenerator() - { - super(); - // Load .NET type and size maps. - // Adjust or add to these lists as new types are added/defined. - // The char '#' will be replaced by the field variable name (any type). - // The char '~' will be replaced by the compacted bit array size (type bit only). - // TODO: I have left a copy of the Java typeMap here - replace with appropriate .NET values. - typeMap.put("bit", new DomainInfo( - "boolean", // .NET code type - "~", // size - "EncodingUtils.writeBooleans(buffer, #)", // encode expression - "# = EncodingUtils.readBooleans(buffer)")); // decode expression - typeMap.put("content", new DomainInfo( - "Content", // .NET code type - "EncodingUtils.encodedContentLength(#)", // size - "EncodingUtils.writeContentBytes(buffer, #)", // encode expression - "# = EncodingUtils.readContent(buffer)")); // decode expression - typeMap.put("long", new DomainInfo( - "long", // .NET code type - "4", // size - "EncodingUtils.writeUnsignedInteger(buffer, #)", // encode expression - "# = buffer.getUnsignedInt()")); // decode expression - typeMap.put("longlong", new DomainInfo( - "long", // .NET code type - "8", // size - "buffer.putLong(#)", // encode expression - "# = buffer.getLong()")); // decode expression - typeMap.put("longstr", new DomainInfo( - "byte[]", // .NET code type - "EncodingUtils.encodedLongstrLength(#)", // size - "EncodingUtils.writeLongStringBytes(buffer, #)", // encode expression - "# = EncodingUtils.readLongstr(buffer)")); // decode expression - typeMap.put("octet", new DomainInfo( - "short", // .NET code type - "1", // size - "EncodingUtils.writeUnsignedByte(buffer, #)", // encode expression - "# = buffer.getUnsigned()")); // decode expression - typeMap.put("short", new DomainInfo( - "int", // .NET code type - "2", // size - "EncodingUtils.writeUnsignedShort(buffer, #)", // encode expression - "# = buffer.getUnsignedShort()")); // decode expression - typeMap.put("shortstr", new DomainInfo( - "AMQShortString", // .NET code type - "EncodingUtils.encodedShortStringLength(#)", // size - "EncodingUtils.writeShortStringBytes(buffer, #)", // encode expression - "# = EncodingUtils.readAMQShortString(buffer)")); // decode expression - typeMap.put("table", new DomainInfo( - "FieldTable", // .NET code type - "EncodingUtils.encodedFieldTableLength(#)", // size - "EncodingUtils.writeFieldTableBytes(buffer, #)", // encode expression - "# = EncodingUtils.readFieldTable(buffer)")); // decode expression - typeMap.put("timestamp", new DomainInfo( - "long", // .NET code type - "8", // size - "EncodingUtils.writeTimestamp(buffer, #)", // encode expression - "# = EncodingUtils.readTimestamp(buffer)")); // decode expression - } - - void processModelTemplate(NamedTemplate template, AmqpVersion version) - { - //To change body of implemented methods use File | Settings | File Templates. - } - - void processClassTemplate(NamedTemplate template, AmqpClass amqpClass, AmqpVersion version) - { - //To change body of implemented methods use File | Settings | File Templates. - } - - void processMethodTemplate(NamedTemplate template, AmqpClass amqpClass, AmqpMethod amqpMethod, AmqpVersion version) - { - //To change body of implemented methods use File | Settings | File Templates. - } - - void processFieldTemplate(NamedTemplate template, AmqpClass amqpClass, AmqpMethod amqpMethod, AmqpField amqpField, AmqpVersion version) - { - //To change body of implemented methods use File | Settings | File Templates. - } - - @Override - protected String prepareFilename(String filenameTemplate, - AmqpClass thisClass, AmqpMethod method, AmqpField field, AmqpVersion version) - { - StringBuffer sb = new StringBuffer(filenameTemplate); - if (thisClass != null) - { - replaceToken(sb, "${CLASS}", thisClass.getName()); - } - if (method != null) - { - replaceToken(sb, "${METHOD}", method.getName()); - } - if (field != null) - { - replaceToken(sb, "${FIELD}", field.getName()); - } - return sb.toString(); - } - - @Override - protected void processClassList(StringBuffer sb, int listMarkerStartIndex, - int listMarkerEndIndex, AmqpModel model, AmqpVersion version) - throws AmqpTemplateException, AmqpTypeMappingException - { - String codeSnippet; - int lend = sb.indexOf(CR, listMarkerStartIndex) + 1; // Include cr at end of line - String tline = sb.substring(listMarkerEndIndex, lend); // Line excluding line marker, including cr - int tokStart = tline.indexOf('$'); - String token = tline.substring(tokStart).trim(); - sb.delete(listMarkerStartIndex, lend); - - // TODO: Add in tokens and calls to their corresponding generator methods here... - if (token.compareTo("${??????????}") == 0) - { - codeSnippet = token; // This is a stub to get the compile working - remove when gen method is present. -// codeSnippet = generateRegistry(model, 8, 4); - } - - else // Oops! - { - throw new AmqpTemplateException("Template token " + token + " unknown."); - } - sb.insert(listMarkerStartIndex, codeSnippet); - } - - @Override - protected void processConstantList(StringBuffer sb, - int listMarkerStartIndex, int listMarkerEndIndex, - AmqpConstantSet constantSet) throws AmqpTemplateException, - AmqpTypeMappingException - { - String codeSnippet; - int lend = sb.indexOf(CR, listMarkerStartIndex) + 1; // Include cr at end of line - String tline = sb.substring(listMarkerEndIndex, lend); // Line excluding line marker, including cr - int tokStart = tline.indexOf('$'); - String token = tline.substring(tokStart).trim(); - sb.delete(listMarkerStartIndex, lend); - - // TODO: Add in tokens and calls to their corresponding generator methods here... - if (token.compareTo("${??????????}") == 0) - { - codeSnippet = token; // This is a stub to get the compile working - remove when gen method is present. -// codeSnippet = generateConstantGetMethods(constantSet, 4, 4); - } - - else // Oops! - { - throw new AmqpTemplateException("Template token " + token + " unknown."); - } - sb.insert(listMarkerStartIndex, codeSnippet); - } - - @Override - protected void processFieldList(StringBuffer sb, int listMarkerStartIndex, - int listMarkerEndIndex, AmqpFieldMap fieldMap, AmqpVersion version) - { - String codeSnippet; - int lend = sb.indexOf(CR, listMarkerStartIndex) + 1; // Include cr at end of line - String tline = sb.substring(listMarkerEndIndex, lend); // Line excluding line marker, including cr - int tokStart = tline.indexOf('$'); - String token = tline.substring(tokStart).trim(); - sb.delete(listMarkerStartIndex, lend); - - // TODO: Add in tokens and calls to their corresponding generator methods here... - if (token.compareTo("${??????????}") == 0) - { - codeSnippet = token; // This is a stub to get the compile working - remove when gen method is present. -// codeSnippet = fieldMap.parseFieldMap(declarationGenerateMethod, -// mangledDeclarationGenerateMethod, 4, 4, this); - } - - else // Oops! - { - throw new AmqpTemplateException("Template token " + token + " unknown."); - } - sb.insert(listMarkerStartIndex, codeSnippet); - } - - @Override - protected void processMethodList(StringBuffer sb, int listMarkerStartIndex, - int listMarkerEndIndex, AmqpClass thisClass) - throws AmqpTemplateException, AmqpTypeMappingException - { - String codeSnippet; - int lend = sb.indexOf(CR, listMarkerStartIndex) + 1; // Include cr at end of line - String tline = sb.substring(listMarkerEndIndex, lend); // Line excluding line marker, including cr - int tokStart = tline.indexOf('$'); - String token = tline.substring(tokStart).trim(); - sb.delete(listMarkerStartIndex, lend); - - // TODO: Add in tokens and calls to their corresponding generator methods here... - if (token.compareTo("${??????????}") == 0) - { - codeSnippet = token; // This is a stub to get the compile working - remove when gen method is present. - } - - else // Oops! - { - throw new AmqpTemplateException("Template token " + token + " unknown."); - } - sb.insert(listMarkerStartIndex, codeSnippet); - } - - @Override - protected void processModelTemplate(NamedTemplate template) - { - // I've put in the Java model here - this can be changed if a different pattern is required. - processTemplate(template, null, null, null, null); - } - - @Override - protected void processClassTemplate(NamedTemplate template, AmqpClass thisClass) - { - // I've put in the Java model here - this can be changed if a different pattern is required. - processTemplate(template, thisClass, null, null, null); - } - - @Override - protected void processMethodTemplate(NamedTemplate template, AmqpClass thisClass, - AmqpMethod method) - { - // I've put in the Java model here - this can be changed if a different pattern is required. - processTemplate(template, thisClass, method, null, null); - } - - @Override - protected void processTemplate(NamedTemplate template, AmqpClass thisClass, - AmqpMethod method, AmqpField field, AmqpVersion version) - { - // I've put in the Java model here - this can be changed if a different pattern is required. - StringBuffer sb = new StringBuffer(template.getTemplate()); - String filename = prepareFilename(getTemplateFileName(sb), thisClass, method, field, version); - try - { - processAllLists(sb, thisClass, method, null); - } - catch (AmqpTemplateException e) - { - System.out.println("WARNING: " + template.getName() + ": " + e.getMessage()); - } - try - { - processAllTokens(sb, thisClass, method, field, null); - } - catch (AmqpTemplateException e) - { - System.out.println("WARNING: " + template.getName() + ": " + e.getMessage()); - } - writeTargetFile(sb, new File(getOutputDirectory() + Utils.FILE_SEPARATOR + filename)); - generatedFileCounter++; - } - - @Override - protected String processToken(String token, AmqpClass thisClass, - AmqpMethod method, AmqpField field, AmqpVersion version) - throws AmqpTemplateException, AmqpTypeMappingException - { - // TODO Auto-generated method stub - return null; - } - - public String getGeneratedType(String domainName, AmqpVersion version) - throws AmqpTypeMappingException - { - String domainType = getDomainType(domainName, version); - if (domainType == null) - { - throw new AmqpTypeMappingException("Domain type \"" + domainName + - "\" not found in Java typemap."); - } - DomainInfo info = typeMap.get(domainType); - if (info == null) - { - throw new AmqpTypeMappingException("Unknown domain: \"" + domainType + "\""); - } - return info.type; - } - - public String prepareClassName(String className) - { - return camelCaseName(className, true); - } - - public String prepareDomainName(String domainName) - { - return camelCaseName(domainName, false); - } - - public String prepareMethodName(String methodName) - { - return camelCaseName(methodName, false); - } - - private String camelCaseName(String name, boolean upperFirstFlag) - { - StringBuffer ccn = new StringBuffer(); - String[] toks = name.split("[-_.\\ ]"); - for (int i = 0; i < toks.length; i++) - { - StringBuffer b = new StringBuffer(toks[i]); - if (upperFirstFlag || i > 0) - { - b.setCharAt(0, Character.toUpperCase(toks[i].charAt(0))); - } - ccn.append(b); - } - return ccn.toString(); - } - - - public static Factory<DotnetGenerator> _factoryInstance = new Factory<DotnetGenerator>() - { - - public DotnetGenerator newInstance() - { - return new DotnetGenerator(); - } - }; - - public static Factory<DotnetGenerator> getFactory() - { - return _factoryInstance; - } - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/GenerateMethod.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/GenerateMethod.java deleted file mode 100644 index 8b0bb99b41..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/GenerateMethod.java +++ /dev/null @@ -1,27 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - - -public interface GenerateMethod -{ - String generate(String domainType, String fieldName, int ordinal, int indentSize, int tabSize); -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/Generator.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/Generator.java deleted file mode 100644 index 5d6e7be527..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/Generator.java +++ /dev/null @@ -1,857 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import org.apache.velocity.Template; -import org.apache.velocity.VelocityContext; -import org.apache.velocity.app.Velocity; -import org.w3c.dom.Node; - -import java.io.File; -import java.io.FileNotFoundException; -import java.io.FileReader; -import java.io.FileWriter; -import java.io.FilenameFilter; -import java.io.IOException; -import java.io.LineNumberReader; -import java.io.StringWriter; -import java.util.ArrayList; -import java.util.Collection; -import java.util.EnumMap; -import java.util.EnumSet; -import java.util.HashMap; -import java.util.Map; - -public abstract class Generator implements LanguageConverter -{ - protected static String CR = Utils.LINE_SEPARATOR; - - - private static final Map<String, Integer> FIXED_SIZE_TYPES = new HashMap<String, Integer>(); - - static - { - FIXED_SIZE_TYPES.put("bit", 1); - FIXED_SIZE_TYPES.put("bitfield", 1); - FIXED_SIZE_TYPES.put("long", 4); - FIXED_SIZE_TYPES.put("longlong", 8); - FIXED_SIZE_TYPES.put("octet", 1); - FIXED_SIZE_TYPES.put("short", 2); - FIXED_SIZE_TYPES.put("timestamp", 8); - - } - - private String _templateDirectory; - private String _outputDirectory; - - public AmqpDomainMap getDomainMap() - { - return _domainMap; - } - - public AmqpConstantSet getConstantSet() - { - return _constantSet; - } - - public AmqpModel getModel() - { - return _model; - } - - abstract public String getNativeType(String type); - - abstract public String getEncodingType(String type); - - - - protected static enum EnumConstOutputTypes - { - OUTPUT_STRING, - OUTPUT_INTEGER, - OUTPUT_DOUBLE; - } - - ; - - public static enum TemplateType - { - model("model"), - clazz("class"), - method("method"), - field("field"); - - private final String _name; - - private TemplateType(String name) - { - _name = name; - } - - public String getName() - { - return _name; - } - } - - ; - - - public static interface Factory<X extends Generator> - { - public X newInstance(); - } - - - protected static final class NamedTemplate - { - private final String _name; - private final String _template; - private final File _file; - - - public NamedTemplate(String relativePath, File templateFile) - { - _file = templateFile; - _name = relativePath + Utils.FILE_SEPARATOR + templateFile.getName(); - - _template = loadTemplate(templateFile); - } - - - public String getName() - { - return _name; - } - - public String getTemplate() - { - return _template; - } - - - public File getFile() - { - return _file; - } - - } - - - private static final String VELOCITY_TEMPLATE_SUFFIX = ".vm"; - private static final String STANDARD_TEMPLATE_SUFFIX = ".tmpl"; - private static FilenameFilter _tmplFileFilter = new FilenameFilter() - { - - public boolean accept(File dir, String name) - { - return name.endsWith(STANDARD_TEMPLATE_SUFFIX) || name.endsWith(VELOCITY_TEMPLATE_SUFFIX); - } - }; - - - // This string is reproduced in every generated file as a comment - // TODO: Tie the version info into the build system. - protected static final String GENERATOR_INFO = "Qpid Gentools v.0.1"; - - - private final Map<TemplateType, Collection<NamedTemplate>> _templates = - new EnumMap<TemplateType, Collection<NamedTemplate>>(TemplateType.class); - - private final Map<TemplateType, Collection<NamedTemplate>> _versionSpecificTemplates = - new EnumMap<TemplateType, Collection<NamedTemplate>>(TemplateType.class); - - - private final AmqpVersionSet _versionSet; - - private final AmqpDomainMap _domainMap; - private final Map<AmqpVersion, AmqpDomainMap> _versionToDomainMapMap = new HashMap<AmqpVersion, AmqpDomainMap>(); - - private final AmqpConstantSet _constantSet; - private final Map<AmqpVersion, AmqpConstantSet> _versionToConstantSetMap = new HashMap<AmqpVersion, AmqpConstantSet>(); - - - public AmqpVersionSet getVersionSet() - { - return _versionSet; - } - - private final AmqpModel _model; - private final Map<AmqpVersion, AmqpModel> _versionToModelMap = new HashMap<AmqpVersion, AmqpModel>(); - - protected int generatedFileCounter; - - public Generator() - { - _versionSet = new AmqpVersionSet(); - _model = new AmqpModel(this); - _constantSet = new AmqpConstantSet(this); - _domainMap = new AmqpDomainMap(this); - - generatedFileCounter = 0; - } - -// public final AmqpVersionSet getVersionSet() -// { -// return _versionSet; -// } - - - public void addVersion(AmqpVersion version) - { - _versionSet.add(version); - if (!_versionToModelMap.containsKey(version)) - { - _versionToModelMap.put(version, new AmqpModel(this)); - } - if (!_versionToDomainMapMap.containsKey(version)) - { - _versionToDomainMapMap.put(version, new AmqpDomainMap(this)); - } - if (!_versionToConstantSetMap.containsKey(version)) - { - _versionToConstantSetMap.put(version, new AmqpConstantSet(this)); - } - } - - public int getNumberGeneratedFiles() - { - return generatedFileCounter; - } - -// public AmqpDomainMap getDomainMap() -// { -// return _domainMap; -// } -// -// public AmqpConstantSet getConstantSet() -// { -// return _constantSet; -// } -// -// -// public AmqpModel getModel() -// { -// return _model; -// } - - public void initializeTemplates() throws IOException - { - - for (TemplateType type : EnumSet.allOf(TemplateType.class)) - { - ArrayList<NamedTemplate> typeTemplates = new ArrayList<NamedTemplate>(); - _templates.put(type, typeTemplates); - ArrayList<NamedTemplate> versionSpecificTypeTemplates = new ArrayList<NamedTemplate>(); - _versionSpecificTemplates.put(type, versionSpecificTypeTemplates); - - File templateDirectory = new File(getTemplateDirectory() + Utils.FILE_SEPARATOR + type.getName()); - File versionTemplateDirectory = new File(getTemplateDirectory() + Utils.FILE_SEPARATOR + type.getName() + Utils.FILE_SEPARATOR + "version"); - - System.out.println("Looking for template files in directory: " + templateDirectory.getAbsoluteFile()); - - File[] templateFiles = templateDirectory.listFiles(_tmplFileFilter); - - File[] versionTemplateFiles = new File[0]; - - System.out.println("Looking for version specific template files in directory: " + versionTemplateDirectory.getAbsoluteFile()); - - if (versionTemplateDirectory.exists()) - { - versionTemplateFiles = versionTemplateDirectory.listFiles(_tmplFileFilter); - } - - if(templateFiles != null) - { - for (File templateFile : templateFiles) - { - System.out.println(type.getName() + " template file(s):"); - System.out.println(" " + templateFile.getCanonicalPath()); - typeTemplates.add(new NamedTemplate(type.getName(), templateFile)); - } - } - - if(versionTemplateFiles != null) - { - for (File versionTemplateFile : versionTemplateFiles) - { - System.out.println(type.getName() + " template file(s):"); - System.out.println(" " + versionTemplateFile.getCanonicalPath()); - versionSpecificTypeTemplates.add(new NamedTemplate(type.getName() + Utils.FILE_SEPARATOR + "version", versionTemplateFile)); - } - } - - } - } - - public String getTemplateDirectory() - { - return _templateDirectory; - } - - - public void setTemplateDirectory(String templateDirectory) - { - _templateDirectory = templateDirectory; - } - - - public void setOutputDirectory(String outputDirectory) - { - _outputDirectory = outputDirectory; - } - - public void generate() - { - prepareTargetDirectory(new File(_outputDirectory), true); - System.out.println("Generation directory: " + _outputDirectory); - - - processModelTemplates(_templates); - - for (AmqpClass amqpClass : _model.getClassMap().values()) - { - processClassTemplates(_templates, amqpClass); - - for (AmqpMethod amqpMethod : amqpClass.getMethodMap().values()) - { - processMethodTemplates(_templates, amqpClass, amqpMethod); - - for (AmqpField amqpField : amqpMethod.getFieldMap().values()) - { - processFieldTemplates(_templates, amqpClass, amqpMethod, amqpField, null); - } - } - } - - - for (AmqpVersion version : _versionSet) - { - AmqpModel model = _versionToModelMap.get(version); - processModelTemplates(_versionSpecificTemplates, version); - - for (AmqpClass amqpClass : model.getClassMap().values()) - { - processClassTemplates(_versionSpecificTemplates, amqpClass, version); - - for (AmqpMethod amqpMethod : amqpClass.getMethodMap().values()) - { - processMethodTemplates(_versionSpecificTemplates, amqpClass, amqpMethod, version); - - for (AmqpField amqpField : amqpMethod.getFieldMap().values()) - { - processFieldTemplates(_versionSpecificTemplates, amqpClass, amqpMethod, amqpField, version); - } - } - } - - } - } - - private void processMethodTemplates(Map<TemplateType, Collection<NamedTemplate>> templates, AmqpClass amqpClass, AmqpMethod amqpMethod, AmqpVersion version) - { - for (NamedTemplate template : templates.get(TemplateType.method)) - { - if(isVelocityTemplate(template)) - { - processVelocityTemplate(template,version,amqpClass,amqpMethod,null); - } - else - { - processMethodTemplate(template, amqpClass, amqpMethod); - } - } - - } - - private void processClassTemplates(Map<TemplateType, Collection<NamedTemplate>> templates, AmqpClass amqpClass, AmqpVersion version) - { - for (NamedTemplate template : templates.get(TemplateType.clazz)) - { - if(isVelocityTemplate(template)) - { - processVelocityTemplate(template,version,amqpClass,null,null); - } - else - { - processClassTemplate(template, amqpClass); - } - } - - } - - - private void processModelTemplates(Map<TemplateType, Collection<NamedTemplate>> templates, AmqpVersion version) - { - for (NamedTemplate template : templates.get(TemplateType.model)) - { - if (isVelocityTemplate(template)) - { - processModelVelocityTemplate(template, version); - } - else - { - processModelTemplate(template, version); - } - } - } - - abstract void processModelTemplate(NamedTemplate template, AmqpVersion version); - - - protected void processModelTemplates(Map<TemplateType, Collection<NamedTemplate>> templates) - { - for (NamedTemplate template : templates.get(TemplateType.model)) - { - if (isVelocityTemplate(template)) - { - processModelVelocityTemplate(template, null); - } - else - { - processModelTemplate(template); - } - } - } - - private boolean isVelocityTemplate(NamedTemplate template) - { - return template.getName().endsWith(VELOCITY_TEMPLATE_SUFFIX); - } - - private void processModelVelocityTemplate(NamedTemplate template, AmqpVersion version) - { - processVelocityTemplate(template,version,null,null,null); - } - - private void processVelocityTemplate(NamedTemplate template, AmqpVersion version, - AmqpClass amqpClass, AmqpMethod amqpMethod, AmqpField amqpField) - { - - VelocityContext context = new VelocityContext(); - - AmqpModel model = _model; - if(version != null) - { - model = _versionToModelMap.get(version); - } - context.put("model", model); - context.put("generator", GENERATOR_INFO); - - if (version != null) - { - context.put("version", version); - } - if(amqpClass != null) - { - context.put("amqpClass", amqpClass); - } - - if(amqpClass != null) - { - context.put("amqpMethod", amqpMethod); - } - - - StringWriter sw = new StringWriter(); - - - try - { - Template velocityTemplate = Velocity.getTemplate(template.getName()); - velocityTemplate.merge(context, sw); - String filename = String.valueOf(context.get("filename")); - - File outputFile = new File(getOutputDirectory() + Utils.FILE_SEPARATOR + filename); - outputFile.getParentFile().mkdirs(); - FileWriter outputFileWriter = new FileWriter(outputFile); - - outputFileWriter.append(sw.toString()); - outputFileWriter.close(); - - } - catch (Exception e) - { - e.printStackTrace(); - } - - - } - - - protected void processClassTemplates(Map<TemplateType, Collection<NamedTemplate>> templates, AmqpClass amqpClass) - { - for (NamedTemplate template : templates.get(TemplateType.clazz)) - { - if(isVelocityTemplate(template)) - { - processVelocityTemplate(template,null,amqpClass,null,null); - } - else - { - processClassTemplate(template, amqpClass); - } - } - } - - protected void processMethodTemplates(Map<TemplateType, Collection<NamedTemplate>> templates, AmqpClass amqpClass, AmqpMethod amqpMethod) - { - for (NamedTemplate template : templates.get(TemplateType.method)) - { - if(isVelocityTemplate(template)) - { - processVelocityTemplate(template,null,amqpClass,amqpMethod,null); - } - else - { - processMethodTemplate(template, amqpClass, amqpMethod); - } - } - } - - - protected void processFieldTemplates(Map<TemplateType, Collection<NamedTemplate>> templates, AmqpClass amqpClass, AmqpMethod amqpMethod, AmqpField amqpField, AmqpVersion amqpVersion) - { - for (NamedTemplate template : templates.get(TemplateType.field)) - { - if(isVelocityTemplate(template)) - { - processVelocityTemplate(template,amqpVersion,amqpClass,amqpMethod,amqpField); - } - else - { - processTemplate(template, amqpClass, amqpMethod, amqpField, amqpVersion); - } - } - } - - - protected void processVersionList(StringBuffer sb, int tokStart, int tokEnd) - { - int lend = sb.indexOf(Utils.LINE_SEPARATOR, tokStart) + 1; // Include cr at end of line - String tline = sb.substring(tokEnd, lend); // Line excluding line marker, including cr - sb.delete(tokStart, lend); - - for (AmqpVersion v : _versionSet) - { - // Insert copy of target line - StringBuffer isb = new StringBuffer(tline); - if (isb.indexOf("${protocol-version-list-entry}") >= 0) - { - String versionListEntry = " { ${major}, ${minor} }" + - (v.equals(_versionSet.last()) ? "" : ","); - replaceToken(isb, "${protocol-version-list-entry}", String.valueOf(versionListEntry)); - } - if (isb.indexOf("${major}") >= 0) - { - replaceToken(isb, "${major}", String.valueOf(v.getMajor())); - } - if (isb.indexOf("${minor}") >= 0) - { - replaceToken(isb, "${minor}", String.valueOf(v.getMinor())); - } - sb.insert(tokStart, isb.toString()); - tokStart += isb.length(); - } - } - - // Helper functions common to all generators - - protected static void prepareTargetDirectory(File dir, boolean createFlag) - { - if (dir.exists()) - { - if (!dir.isDirectory()) - { - throw new TargetDirectoryException("\"" + dir.getAbsolutePath() + - "\" exists, but is not a directory."); - } - } - else if (createFlag) // Create dir - { - if (!dir.mkdirs()) - { - throw new TargetDirectoryException("Unable to create directory \"" + - dir.getAbsolutePath() + "\"."); - } - } - else - { - throw new TargetDirectoryException("Directory \"" + dir.getAbsolutePath() + - "\" not found."); - } - - } - - protected void processAllLists(StringBuffer sb, AmqpClass thisClass, AmqpMethod method, AmqpVersion version) - { - AmqpModel model = (version == null) ? _model : _versionToModelMap.get(version); - - - int lstart = sb.indexOf("%{"); - while (lstart != -1) - { - int lend = sb.indexOf("}", lstart + 2); - if (lend > 0) - { - String listToken = sb.substring(lstart + 2, lend); - if (listToken.compareTo("VLIST") == 0) - { - processVersionList(sb, lstart, lend + 1); - } - else if (listToken.compareTo("CLIST") == 0) - { - processClassList(sb, lstart, lend + 1, model, version); - } - else if (listToken.compareTo("MLIST") == 0) - { - processMethodList(sb, lstart, lend + 1, thisClass); - } - else if (listToken.compareTo("FLIST") == 0) - { - // Pass the FieldMap from either a class or a method. - // If this is called from a class-level template, we assume that the - // class field list is required. In this case, method will be null. - processFieldList(sb, lstart, lend + 1, - (method == null ? thisClass.getFieldMap() : method.getFieldMap()), - version); - } - else if (listToken.compareTo("TLIST") == 0) - { - processConstantList(sb, lstart, lend + 1, _constantSet); - } - else - { - throw new AmqpTemplateException("Unknown list token \"%{" + listToken + - "}\" found in template at index " + lstart + "."); - } - } - lstart = sb.indexOf("%{", lstart + 1); - } - } - - protected void processAllTokens(StringBuffer sb, AmqpClass thisClass, AmqpMethod method, AmqpField field, - AmqpVersion version) - { - int lstart = sb.indexOf("${"); - while (lstart != -1) - { - int lend = sb.indexOf("}", lstart + 2); - if (lend > 0) - { - String token = sb.substring(lstart, lend + 1); - replaceToken(sb, lstart, token, processToken(token, thisClass, method, field, version)); - } - lstart = sb.indexOf("${", lstart); - } - } - - protected static void writeTargetFile(StringBuffer sb, File f) - { - try - { - f.getParentFile().mkdirs(); - FileWriter fw = new FileWriter(f); - fw.write(sb.toString().toCharArray()); - fw.flush(); - fw.close(); - } - catch (IOException e) - { - throw new AmqpTemplateException(e.getMessage()); - } - } - - - protected static String getTemplateFileName(StringBuffer sb) - { - if (sb.charAt(0) != '&') - { - throw new AmqpTemplateException("No filename marker &{filename} found at start of template."); - } - int cr = sb.indexOf(Utils.LINE_SEPARATOR); - if (cr < 0) - { - throw new AmqpTemplateException("Bad template structure - unable to find first line."); - } - String fileName = sb.substring(2, cr - 1); - sb.delete(0, cr + 1); - return fileName; - } - - protected static void replaceToken(StringBuffer sb, String token, String replacement) - { - replaceToken(sb, 0, token, replacement); - } - - protected static void replaceToken(StringBuffer sb, int index, String token, String replacement) - { - if (replacement != null) - { - int start = sb.indexOf(token, index); - if (start != -1) - { - int len = token.length(); - // Find first letter in token and determine if it is capitalized - char firstTokenLetter = getFirstLetter(token); - if (firstTokenLetter != 0 && Character.isUpperCase(firstTokenLetter)) - { - sb.replace(start, start + len, Utils.firstUpper(replacement)); - } - else - { - sb.replace(start, start + len, replacement); - } - } - } - } - - private static char getFirstLetter(String str) - { - int len = str.length(); - int index = 0; - char tokChar = str.charAt(index); - while (!Character.isLetter(tokChar) && index < len - 1) - { - tokChar = str.charAt(++index); - } - if (Character.isLetter(tokChar)) - { - return tokChar; - } - return 0; - } - - private static String loadTemplate(File f) - { - try - { - StringBuffer sb = new StringBuffer(); - FileReader fr = new FileReader(f); - LineNumberReader lnr = new LineNumberReader(fr); - String line = lnr.readLine(); - while (line != null) - { - - sb.append(line); - sb.append(Utils.LINE_SEPARATOR); - - line = lnr.readLine(); - } - lnr.close(); - fr.close(); - return sb.toString(); - } - catch (FileNotFoundException e) - { - throw new AmqpTemplateException("File not found: " + e.getMessage()); - } - catch (IOException e) - { - throw new AmqpTemplateException("IOException: " + e.getMessage()); - } - } - - public String getDomainType(String domainName, AmqpVersion version) - { - if (version == null) - { - version = _versionSet.first(); - } - return getDomainMap().getDomainType(domainName, version); - } - - - public void addFromNode(Node amqpNode, AmqpVersion version) - { - // 1c. Extract domains - getConstantSet().addFromNode(amqpNode, 0, version); - _versionToConstantSetMap.get(version).addFromNode(amqpNode, 0, version); - - // 1d. Extract domains - getDomainMap().addFromNode(amqpNode, 0, version); - _versionToDomainMapMap.get(version).addFromNode(amqpNode, 0, version); - - // 1e. Extract class/method/field heirarchy - getModel().addFromNode(amqpNode, 0, version); - _versionToModelMap.get(version).addFromNode(amqpNode, 0, version); - } - - - public String getOutputDirectory() - { - return _outputDirectory; - } - - public String prepareConstantName(String constantName) - { - return prepareDomainName(constantName); - } - - - public boolean isFixedSizeType(String type) - { - return FIXED_SIZE_TYPES.containsKey(type); - } - - - public int getTypeSize(String type) - { - return FIXED_SIZE_TYPES.get(type); - } - - - - // Model-level template processing - abstract protected void processModelTemplate(NamedTemplate template); - - // Class-level template processing - abstract protected void processClassTemplate(NamedTemplate template, AmqpClass thisClass); - - // Method-level template processing - abstract protected void processMethodTemplate(NamedTemplate template, AmqpClass thisClass, - AmqpMethod method); - - // Field-level template processing - abstract protected void processTemplate(NamedTemplate template, AmqpClass thisClass, - AmqpMethod method, AmqpField field, AmqpVersion version); - - abstract protected String prepareFilename(String filenameTemplate, AmqpClass thisClass, AmqpMethod method, - AmqpField field, AmqpVersion version); - - abstract protected String processToken(String token, AmqpClass thisClass, AmqpMethod method, - AmqpField field, AmqpVersion version); - - abstract protected void processClassList(StringBuffer sb, int listMarkerStartIndex, int listMarkerEndIndex, - AmqpModel model, AmqpVersion version); - - abstract protected void processMethodList(StringBuffer sb, int listMarkerStartIndex, int listMarkerEndIndex, - AmqpClass thisClass); - - - abstract protected void processFieldList(StringBuffer sb, int listMarkerStartIndex, int listMarkerEndIndex, - AmqpFieldMap fieldMap, AmqpVersion version); - - abstract protected void processConstantList(StringBuffer sb, int listMarkerStartIndex, int listMarkerEndIndex, - AmqpConstantSet constantSet); - - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/JavaGenerator.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/JavaGenerator.java deleted file mode 100644 index 7730fca1bd..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/JavaGenerator.java +++ /dev/null @@ -1,1826 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.io.File; -import java.util.Iterator; -import java.util.List; -import java.util.TreeMap; - -public class JavaGenerator extends Generator -{ - // TODO: Move this to parent class - protected static final int FIELD_NAME = 0; - protected static final int FIELD_CODE_TYPE = 1; - - private class DomainInfo - { - final public String type; - final public String size; - final public String encodingType; - final public String encodeExpression; - final public String decodeExpression; - - public DomainInfo(String domain, String size, String encodingType, String encodeExpression, String decodeExpression) - { - this.type = domain; - this.size = size; - this.encodeExpression = encodeExpression; - this.decodeExpression = decodeExpression; - this.encodingType = encodingType; - } - } - - private static TreeMap<String, DomainInfo> typeMap = new TreeMap<String, DomainInfo>(); - - // Methods used for generation of code snippets called from the field map parsers - - // Common methods - private final CommandGenerateMethod declarationGenerateMethod = new CommandGenerateMethod() - { - public String generate(String codeType, AmqpField field, AmqpVersionSet versionSet, int indentSize, int tabSize, boolean notLast) - { - return generateFieldDeclaration(codeType, field, versionSet, indentSize, tabSize, notLast); - } - }; - - private MangledGenerateMethod mangledDeclarationGenerateMethod = new MangledGenerateMethod() - { - public String generate(AmqpField field, int indentSize, int tabSize, boolean notLast) - { - return generateMangledFieldDeclaration(field, indentSize, tabSize, notLast); - } - }; - - // Methods for MessageBody classes - private CommandGenerateMethod mbGetGenerateMethod = new CommandGenerateMethod() - { - public String generate(String codeType, AmqpField field, AmqpVersionSet versionSet, int indentSize, int tabSize, boolean notLast) - { - return generateMbGetMethod(codeType, field, versionSet, indentSize, tabSize, notLast); //To change body of implemented methods use File | Settings | File Templates. - } - }; - - private MangledGenerateMethod mbMangledGetGenerateMethod = new MangledGenerateMethod() - { - public String generate(AmqpField field, int indentSize, int tabSize, boolean notLast) - { - return generateMbMangledGetMethod(field, indentSize, tabSize, notLast); - } - }; - private CommandGenerateMethod mbParamListGenerateMethod = new CommandGenerateMethod() - { - public String generate(String codeType, AmqpField field, AmqpVersionSet versionSet, int indentSize, int tabSize, boolean notLast) - { - return generateMbParamList(codeType, field, versionSet, indentSize, tabSize, notLast); - } - }; - private CommandGenerateMethod mbPassedParamListGenerateMethod = new CommandGenerateMethod() - { - public String generate(String codeType, AmqpField field, AmqpVersionSet versionSet, int indentSize, int tabSize, boolean notLast) - { - return generateMbPassedParamList(codeType, field, versionSet, indentSize, tabSize, notLast); - } - }; - private MangledGenerateMethod mbMangledParamListGenerateMethod = new MangledGenerateMethod() - { - public String generate(AmqpField field, int indentSize, int tabSize, boolean notLast) - { - return generateMbMangledParamList(field, indentSize, tabSize, notLast); - } - }; - private MangledGenerateMethod mbMangledPassedParamListGenerateMethod = new MangledGenerateMethod() - { - public String generate(AmqpField field, int indentSize, int tabSize, boolean notLast) - { - return generateMbMangledPassedParamList(field, indentSize, tabSize, notLast); - } - }; - private CommandGenerateMethod mbBodyInitGenerateMethod = new CommandGenerateMethod() - { - public String generate(String codeType, AmqpField field, AmqpVersionSet versionSet, int indentSize, int tabSize, boolean notLast) - { - return generateMbBodyInit(codeType, field, versionSet, indentSize, tabSize, notLast); - } - }; - private MangledGenerateMethod mbMangledBodyInitGenerateMethod = new MangledGenerateMethod() - { - public String generate(AmqpField field, int indentSize, int tabSize, boolean notLast) - { - return generateMbMangledBodyInit(field, indentSize, tabSize, notLast); - } - }; - private GenerateMethod mbSizeGenerateMethod = new GenerateMethod() - { - public String generate(String domainType, String fieldName, int ordinal, int indentSize, int tabSize) - { - return generateMbFieldSize(domainType, fieldName, ordinal, indentSize, tabSize); - } - }; - private BitFieldGenerateMethod mbBitSizeGenerateMethod = new BitFieldGenerateMethod() - { - public String generate(List<String> bitFieldList, int ordinal, int indentSize, int tabSize) - { - return generateMbBitArrayFieldSize(bitFieldList, ordinal, indentSize, tabSize); - } - }; - private GenerateMethod mbEncodeGenerateMethod = new GenerateMethod() - { - public String generate(String domainType, String fieldName, int ordinal, int indentSize, int tabSize) - { - return generateMbFieldEncode(domainType, fieldName, ordinal, indentSize, tabSize); - } - }; - private BitFieldGenerateMethod mbBitEncodeGenerateMethod = new BitFieldGenerateMethod() - { - public String generate(List<String> bitFieldList, int ordinal, int indentSize, int tabSize) - { - return generateMbBitFieldEncode(bitFieldList, ordinal, indentSize, tabSize); - } - }; - private GenerateMethod mbDecodeGenerateMethod = new GenerateMethod() - { - public String generate(String domainType, String fieldName, int ordinal, int indentSize, int tabSize) - { - return generateMbFieldDecode(domainType, fieldName, ordinal, indentSize, tabSize); - } - }; - private BitFieldGenerateMethod mbBitDecodeGenerateMethod = new BitFieldGenerateMethod() - { - public String generate(List<String> bitFieldList, int ordinal, int indentSize, int tabSize) - { - return generateMbBitFieldDecode(bitFieldList, ordinal, indentSize, tabSize); - } - }; - private GenerateMethod mbToStringGenerateMethod = new GenerateMethod() - { - public String generate(String domainType, String fieldName, int ordinal, int indentSize, int tabSize) - { - return generateMbFieldToString(domainType, fieldName, ordinal, indentSize, tabSize); - } - }; - private BitFieldGenerateMethod mbBitToStringGenerateMethod = new BitFieldGenerateMethod() - { - public String generate(List<String> bitFieldList, int ordinal, int indentSize, int tabSize) - { - return generateMbBitFieldToString(bitFieldList, ordinal, indentSize, tabSize); - } - }; - - // Methods for PropertyContentHeader classes - private CommandGenerateMethod pchClearGenerateMethod = new CommandGenerateMethod() - { - public String generate(String codeType, AmqpField field, AmqpVersionSet versionSet, int indentSize, int tabSize, boolean notLast) - { - return generatePchClearMethod(codeType, field, versionSet, indentSize, tabSize, notLast); - } - }; - private MangledGenerateMethod pchMangledClearGenerateMethod = new MangledGenerateMethod() - { - public String generate(AmqpField field, int indentSize, int tabSize, boolean notLast) - { - return generatePchMangledClearMethod(field, indentSize, tabSize, notLast); - } - }; - private CommandGenerateMethod pchGetGenerateMethod = new CommandGenerateMethod() - { - public String generate(String codeType, AmqpField field, AmqpVersionSet versionSet, int indentSize, int tabSize, boolean notLast) - { - return generatePchGetMethod(codeType, field, versionSet, indentSize, tabSize, notLast); - } - }; - private MangledGenerateMethod pchMangledGetGenerateMethod = new MangledGenerateMethod() - { - public String generate(AmqpField field, int indentSize, int tabSize, boolean notLast) - { - return generatePchMangledGetMethod(field, indentSize, tabSize, notLast); - } - }; - private CommandGenerateMethod pchSetGenerateMethod = new CommandGenerateMethod() - { - public String generate(String codeType, AmqpField field, AmqpVersionSet versionSet, int indentSize, int tabSize, boolean notLast) - { - return generatePchSetMethod(codeType, field, versionSet, indentSize, tabSize, notLast); - } - }; - private MangledGenerateMethod pchMangledSetGenerateMethod = new MangledGenerateMethod() - { - public String generate(AmqpField field, int indentSize, int tabSize, boolean notLast) - { - return generatePchMangledSetMethod(field, indentSize, tabSize, notLast); - } - }; - private GenerateMethod pchSizeGenerateMethod = new GenerateMethod() - { - public String generate(String domainType, String fieldName, int ordinal, int indentSize, int tabSize) - { - return generatePchFieldSize(domainType, fieldName, ordinal, indentSize, tabSize); - } - }; - private BitFieldGenerateMethod pchBitSizeGenerateMethod = new BitFieldGenerateMethod() - { - public String generate(List<String> bitFieldList, int ordinal, int indentSize, int tabSize) - { - return generatePchBitArrayFieldSize(bitFieldList, ordinal, indentSize, tabSize); - } - }; - private GenerateMethod pchEncodeGenerateMethod = new GenerateMethod() - { - public String generate(String domainType, String fieldName, int ordinal, int indentSize, int tabSize) - { - return generatePchFieldEncode(domainType, fieldName, ordinal, indentSize, tabSize); - } - }; - private BitFieldGenerateMethod pchBitEncodeGenerateMethod = new BitFieldGenerateMethod() - { - public String generate(List<String> bitFieldList, int ordinal, int indentSize, int tabSize) - { - return generatePchBitFieldEncode(bitFieldList, ordinal, indentSize, tabSize); - } - }; - private GenerateMethod pchDecodeGenerateMethod = new GenerateMethod() - { - public String generate(String domainType, String fieldName, int ordinal, int indentSize, int tabSize) - { - return generatePchFieldDecode(domainType, fieldName, ordinal, indentSize, tabSize); - } - }; - private BitFieldGenerateMethod pchBitDecodeGenerateMethod = new BitFieldGenerateMethod() - { - public String generate(List<String> bitFieldList, int ordinal, int indentSize, int tabSize) - { - return generatePchBitFieldDecode(bitFieldList, ordinal, indentSize, tabSize); - } - }; - private GenerateMethod pchGetPropertyFlagsGenerateMethod = new GenerateMethod() - { - public String generate(String domainType, String fieldName, int ordinal, int indentSize, int tabSize) - { - return generatePchGetPropertyFlags(domainType, fieldName, ordinal, indentSize, tabSize); - } - }; - private BitFieldGenerateMethod pchBitGetPropertyFlagsGenerateMethod = new BitFieldGenerateMethod() - { - public String generate(List<String> bitFieldList, int ordinal, int indentSize, int tabSize) - { - return generatePchBitGetPropertyFlags(bitFieldList, ordinal, indentSize, tabSize); - } - }; - private GenerateMethod pchSetPropertyFlagsGenerateMethod = new GenerateMethod() - { - public String generate(String domainType, String fieldName, int ordinal, int indentSize, int tabSize) - { - return generatePchSetPropertyFlags(domainType, fieldName, ordinal, indentSize, tabSize); - } - }; - private BitFieldGenerateMethod pchBitSetPropertyFlagsGenerateMethod = new BitFieldGenerateMethod() - { - public String generate(List<String> bitFieldList, int ordinal, int indentSize, int tabSize) - { - return generatePchBitSetPropertyFlags(bitFieldList, ordinal, indentSize, tabSize); - } - }; - - - public String getNativeType(String type) - { - return typeMap.get(type).type; - } - - public String getEncodingType(String type) - { - return typeMap.get(type).encodingType; - } - - - public JavaGenerator() - { - super(); - // Load Java type and size maps. - // Adjust or add to these lists as new types are added/defined. - // The char '#' will be replaced by the field variable name (any type). - // The char '~' will be replaced by the compacted bit array size (type bit only). - typeMap.put("bit", new DomainInfo( - "boolean", // Java code type - "~", // size - "Boolean", // Java code type - "EncodingUtils.writeBooleans(buffer, #)", // encode expression - "# = EncodingUtils.readBooleans(buffer)")); // decode expression - typeMap.put("bitfield", new DomainInfo( - "byte", // Java code type - "~", // size - "Bitfield", - "EncodingUtils.writeBooleans(buffer, #)", // encode expression - "# = EncodingUtils.readBooleans(buffer)")); // decode expression - - typeMap.put("content", new DomainInfo( - "Content", // Java code type - "EncodingUtils.encodedContentLength(#)", // size - "Content", // Java code type - "EncodingUtils.writeContentBytes(buffer, #)", // encode expression - "# = EncodingUtils.readContent(buffer)")); // decode expression - typeMap.put("long", new DomainInfo( - "long", // Java code type - "4", // size - "UnsignedInteger", // Java code type - "EncodingUtils.writeUnsignedInteger(buffer, #)", // encode expression - "# = buffer.getUnsignedInt()")); // decode expression - typeMap.put("longlong", new DomainInfo( - "long", // Java code type - "8", // size - "Long", - "buffer.putLong(#)", // encode expression - "# = buffer.getLong()")); // decode expression - typeMap.put("longstr", new DomainInfo( - "byte[]", // Java code type - "EncodingUtils.encodedLongstrLength(#)", // size - "Bytes", - "EncodingUtils.writeLongStringBytes(buffer, #)", // encode expression - "# = EncodingUtils.readLongstr(buffer)")); // decode expression - typeMap.put("octet", new DomainInfo( - "short", // Java code type - "1", // size - "UnsignedByte", - "EncodingUtils.writeUnsignedByte(buffer, #)", // encode expression - "# = buffer.getUnsigned()")); // decode expression - typeMap.put("short", new DomainInfo( - "int", // Java code type - "2", // size - "UnsignedShort", - "EncodingUtils.writeUnsignedShort(buffer, #)", // encode expression - "# = buffer.getUnsignedShort()")); // decode expression - typeMap.put("shortstr", new DomainInfo( - "AMQShortString", // Java code type - "EncodingUtils.encodedShortStringLength(#)", // size - "AMQShortString", // Java code type - "EncodingUtils.writeShortStringBytes(buffer, #)", // encode expression - "# = EncodingUtils.readAMQShortString(buffer)")); // decode expression - typeMap.put("table", new DomainInfo( - "FieldTable", // Java code type - "EncodingUtils.encodedFieldTableLength(#)", // size - "FieldTable", // Java code type - "EncodingUtils.writeFieldTableBytes(buffer, #)", // encode expression - "# = EncodingUtils.readFieldTable(buffer)")); // decode expression - typeMap.put("timestamp", new DomainInfo( - "long", // Java code type - "8", // size - "Timestamp", - "EncodingUtils.writeTimestamp(buffer, #)", // encode expression - "# = EncodingUtils.readTimestamp(buffer)")); // decode expression - } - - // === Start of methods for Interface LanguageConverter === - - public String prepareClassName(String className) - { - return camelCaseName(className, true); - } - - public String prepareMethodName(String methodName) - { - return camelCaseName(methodName, false); - } - - public String prepareDomainName(String domainName) - { - return camelCaseName(domainName, false); - } - - - public String getGeneratedType(String domainName, AmqpVersion version) - { - String domainType = getDomainType(domainName, version); - if (domainType == null) - { - throw new AmqpTypeMappingException("Domain type \"" + domainName + - "\" not found in Java typemap."); - } - DomainInfo info = typeMap.get(domainType); - if (info == null) - { - throw new AmqpTypeMappingException("Unknown domain: \"" + domainType + "\""); - } - return info.type; - } - - // === Abstract methods from class Generator - Java-specific implementations === - - @Override - protected String prepareFilename(String filenameTemplate, AmqpClass thisClass, AmqpMethod method, - AmqpField field, AmqpVersion version) - { - StringBuffer sb = new StringBuffer(filenameTemplate); - if (thisClass != null) - { - replaceToken(sb, "${CLASS}", thisClass.getName()); - } - if (method != null) - { - replaceToken(sb, "${METHOD}", method.getName()); - } - if (field != null) - { - replaceToken(sb, "${FIELD}", field.getName()); - } - if (version != null) - { - replaceToken(sb, "${MAJOR}", String.valueOf(version.getMajor())); - replaceToken(sb, "${MINOR}", String.valueOf(version.getMinor())); - } - return sb.toString(); - } - - @Override - protected void processModelTemplate(NamedTemplate template) - { - processTemplate(template, null, null, null, null); - } - - @Override - protected void processClassTemplate(NamedTemplate template, AmqpClass thisClass) - { - processTemplate(template, thisClass, null, null, - thisClass.getVersionSet().size() == 1 ? thisClass.getVersionSet().first() : null); - } - - @Override - protected void processMethodTemplate(NamedTemplate template, AmqpClass thisClass, - AmqpMethod method) - { - processTemplate(template, thisClass, method, null, - thisClass.getVersionSet().size() == 1 ? thisClass.getVersionSet().first() : null); - } - - protected void processFieldTemplate(NamedTemplate template, AmqpClass thisClass, - AmqpMethod method, AmqpField field) - { - processTemplate(template, thisClass, method, field, - thisClass.getVersionSet().size() == 1 ? thisClass.getVersionSet().first() : null); - } - - @Override - protected void processTemplate(NamedTemplate template, AmqpClass thisClass, - AmqpMethod method, AmqpField field, AmqpVersion version) - { - StringBuffer sb = new StringBuffer(template.getTemplate()); - String filename = prepareFilename(getTemplateFileName(sb), thisClass, method, field, version); - processTemplate(sb, thisClass, method, field, template.getName(), version); - writeTargetFile(sb, new File(getOutputDirectory() + Utils.FILE_SEPARATOR + filename)); - generatedFileCounter++; - } - - protected void processTemplate(StringBuffer sb, AmqpClass thisClass, AmqpMethod method, - AmqpField field, String templateFileName, AmqpVersion version) - { - try - { - processAllLists(sb, thisClass, method, version); - } - catch (AmqpTemplateException e) - { - System.out.println("WARNING: " + templateFileName + ": " + e.getMessage()); - } - try - { - processAllTokens(sb, thisClass, method, field, version); - } - catch (AmqpTemplateException e) - { - System.out.println("WARNING: " + templateFileName + ": " + e.getMessage()); - } - } - - @Override - protected String processToken(String token, AmqpClass thisClass, AmqpMethod method, AmqpField field, - AmqpVersion version) - { - if (token.compareTo("${GENERATOR}") == 0) - { - return GENERATOR_INFO; - } - if (token.compareTo("${CLASS}") == 0 && thisClass != null) - { - return thisClass.getName(); - } - if (token.compareTo("${CLASS_ID_INIT}") == 0 && thisClass != null) - { - return generateIndexInitializer("registerClassId", thisClass.getIndexMap(), 8); - } - if (token.compareTo("${METHOD}") == 0 && method != null) - { - return method.getName(); - } - if (token.compareTo("${METHOD_ID_INIT}") == 0 && method != null) - { - return generateIndexInitializer("registerMethodId", method.getIndexMap(), 8); - } - if (token.compareTo("${FIELD}") == 0 && field != null) - { - return field.getName(); - } - - // This token is used only with class or method-level templates - if (token.compareTo("${pch_property_flags_declare}") == 0) - { - return generatePchPropertyFlagsDeclare(); - } - else if (token.compareTo("${pch_property_flags_initializer}") == 0) - { - int mapSize = method == null ? thisClass.getFieldMap().size() : method.getFieldMap().size(); - return generatePchPropertyFlagsInitializer(mapSize); - } - else if (token.compareTo("${pch_compact_property_flags_initializer}") == 0) - { - return generatePchCompactPropertyFlagsInitializer(thisClass, 8, 4); - } - else if (token.compareTo("${pch_compact_property_flags_check}") == 0) - { - return generatePchCompactPropertyFlagsCheck(thisClass, 8, 4); - } - - // Oops! - throw new AmqpTemplateException("Template token " + token + " unknown."); - } - - @Override - protected void processClassList(StringBuffer sb, int listMarkerStartIndex, int listMarkerEndIndex, - AmqpModel model, AmqpVersion version) - { - String codeSnippet; - int lend = sb.indexOf(CR, listMarkerStartIndex) + 1; // Include cr at end of line - String tline = sb.substring(listMarkerEndIndex, lend); // Line excluding line marker, including cr - int tokStart = tline.indexOf('$'); - String token = tline.substring(tokStart).trim(); - sb.delete(listMarkerStartIndex, lend); - - if (token.compareTo("${reg_map_put_method}") == 0) - { - codeSnippet = generateRegistry(model, 8, 4); - } - - else // Oops! - { - throw new AmqpTemplateException("Template token " + token + " unknown."); - } - - sb.insert(listMarkerStartIndex, codeSnippet); - } - - @Override - protected void processMethodList(StringBuffer sb, int listMarkerStartIndex, int listMarkerEndIndex, - AmqpClass thisClass) - { - String codeSnippet; - int lend = sb.indexOf(CR, listMarkerStartIndex) + 1; // Include cr at end of line - String tline = sb.substring(listMarkerEndIndex, lend); // Line excluding line marker, including cr - int tokStart = tline.indexOf('$'); - String token = tline.substring(tokStart).trim(); - sb.delete(listMarkerStartIndex, lend); - - //TODO - we don't have any cases of this (yet). - if (token.compareTo("${???}") == 0) - { - codeSnippet = token; - } - else // Oops! - { - throw new AmqpTemplateException("Template token " + token + " unknown."); - } - - sb.insert(listMarkerStartIndex, codeSnippet); - } - - @Override - protected void processFieldList(StringBuffer sb, int listMarkerStartIndex, int listMarkerEndIndex, - AmqpFieldMap fieldMap, AmqpVersion version) - { - String codeSnippet; - int lend = sb.indexOf(CR, listMarkerStartIndex) + 1; // Include cr at end of line - String tline = sb.substring(listMarkerEndIndex, lend); // Line excluding line marker, including cr - int tokStart = tline.indexOf('$'); - String token = tline.substring(tokStart).trim(); - sb.delete(listMarkerStartIndex, lend); - - // Field declarations - common to MethodBody and PropertyContentHeader classes - if (token.compareTo("${field_declaration}") == 0) - { - codeSnippet = fieldMap.parseFieldMap(declarationGenerateMethod, - mangledDeclarationGenerateMethod, 4, 4, this); - } - - // MethodBody classes - else if (token.compareTo("${mb_field_get_method}") == 0) - { - codeSnippet = fieldMap.parseFieldMap(mbGetGenerateMethod, - mbMangledGetGenerateMethod, 4, 4, this); - } - else if (token.compareTo("${mb_field_parameter_list}") == 0) - { - // <cringe> The code generated by this is ugly... It puts a comma on a line by itself! - // TODO: Find a more elegant solution here sometime... - codeSnippet = fieldMap.size() > 0 ? Utils.createSpaces(42) + "," + CR : ""; - // </cringe> - codeSnippet += fieldMap.parseFieldMap(mbParamListGenerateMethod, - mbMangledParamListGenerateMethod, 42, 4, this); - } - - else if (token.compareTo("${mb_field_passed_parameter_list}") == 0) - { - // <cringe> The code generated by this is ugly... It puts a comma on a line by itself! - // TODO: Find a more elegant solution here sometime... - codeSnippet = fieldMap.size() > 0 ? Utils.createSpaces(42) + "," + CR : ""; - // </cringe> - codeSnippet += fieldMap.parseFieldMap(mbPassedParamListGenerateMethod, - mbMangledPassedParamListGenerateMethod, 42, 4, this); - } - else if (token.compareTo("${mb_field_body_initialize}") == 0) - { - codeSnippet = fieldMap.parseFieldMap(mbBodyInitGenerateMethod, - mbMangledBodyInitGenerateMethod, 8, 4, this); - } - else if (token.compareTo("${mb_field_size}") == 0) - { - codeSnippet = fieldMap.parseFieldMapOrdinally(mbSizeGenerateMethod, - mbBitSizeGenerateMethod, 8, 4, this); - } - else if (token.compareTo("${mb_field_encode}") == 0) - { - codeSnippet = fieldMap.parseFieldMapOrdinally(mbEncodeGenerateMethod, - mbBitEncodeGenerateMethod, 8, 4, this); - } - else if (token.compareTo("${mb_field_decode}") == 0) - { - codeSnippet = fieldMap.parseFieldMapOrdinally(mbDecodeGenerateMethod, - mbBitDecodeGenerateMethod, 8, 4, this); - } - else if (token.compareTo("${mb_field_to_string}") == 0) - { - codeSnippet = fieldMap.parseFieldMapOrdinally(mbToStringGenerateMethod, - mbBitToStringGenerateMethod, 8, 4, this); - } - - // PropertyContentHeader classes - else if (token.compareTo("${pch_field_list_size}") == 0) - { - codeSnippet = fieldMap.parseFieldMapOrdinally(pchSizeGenerateMethod, - pchBitSizeGenerateMethod, 12, 4, this); - } - else if (token.compareTo("${pch_field_list_payload}") == 0) - { - codeSnippet = fieldMap.parseFieldMapOrdinally(pchEncodeGenerateMethod, - pchBitEncodeGenerateMethod, 12, 4, this); - } - else if (token.compareTo("${pch_field_list_decode}") == 0) - { - codeSnippet = fieldMap.parseFieldMapOrdinally(pchDecodeGenerateMethod, - pchBitDecodeGenerateMethod, 12, 4, this); - } - else if (token.compareTo("${pch_get_compact_property_flags}") == 0) - { - codeSnippet = fieldMap.parseFieldMapOrdinally(pchGetPropertyFlagsGenerateMethod, - pchBitGetPropertyFlagsGenerateMethod, 8, 4, this); - } - else if (token.compareTo("${pch_set_compact_property_flags}") == 0) - { - codeSnippet = fieldMap.parseFieldMapOrdinally(pchSetPropertyFlagsGenerateMethod, - pchBitSetPropertyFlagsGenerateMethod, 8, 4, this); - } - else if (token.compareTo("${pch_field_clear_methods}") == 0) - { - codeSnippet = fieldMap.parseFieldMap(pchClearGenerateMethod, - pchMangledClearGenerateMethod, 4, 4, this); - } - else if (token.compareTo("${pch_field_get_methods}") == 0) - { - codeSnippet = fieldMap.parseFieldMap(pchGetGenerateMethod, - pchMangledGetGenerateMethod, 4, 4, this); - } - else if (token.compareTo("${pch_field_set_methods}") == 0) - { - codeSnippet = fieldMap.parseFieldMap(pchSetGenerateMethod, - pchMangledSetGenerateMethod, 4, 4, this); - } - - else // Oops! - { - throw new AmqpTemplateException("Template token " + token + " unknown."); - } - sb.insert(listMarkerStartIndex, codeSnippet); - } - - @Override - protected void processConstantList(StringBuffer sb, int listMarkerStartIndex, int listMarkerEndIndex, - AmqpConstantSet constantSet) - { - String codeSnippet; - int lend = sb.indexOf(CR, listMarkerStartIndex) + 1; // Include cr at end of line - String tline = sb.substring(listMarkerEndIndex, lend); // Line excluding line marker, including cr - int tokStart = tline.indexOf('$'); - String token = tline.substring(tokStart).trim(); - sb.delete(listMarkerStartIndex, lend); - - if (token.compareTo("${const_get_method}") == 0) - { - codeSnippet = generateConstantGetMethods(constantSet, 4, 4); - } - - else // Oops! - { - throw new AmqpTemplateException("Template token " + token + " unknown."); - } - - sb.insert(listMarkerStartIndex, codeSnippet); - } - - // === Protected and private helper functions unique to Java implementation === - - // Methods used for generation of code snippets called from the field map parsers - - // Common methods - - protected String generateFieldDeclaration(String codeType, AmqpField field, - AmqpVersionSet versionSet, int indentSize, int tabSize, boolean nextFlag) - { - return Utils.createSpaces(indentSize) + "public " + codeType + " " + field.getName() + - "; // AMQP version(s): " + versionSet + CR; - } - - protected String generateMangledFieldDeclaration(AmqpField field, int indentSize, - int tabSize, boolean nextFlag) - { - StringBuffer sb = new StringBuffer(); - Iterator<String> dItr = field.getDomainMap().keySet().iterator(); - int domainCntr = 0; - while (dItr.hasNext()) - { - String domainName = dItr.next(); - AmqpVersionSet versionSet = field.getDomainMap().get(domainName); - String codeType = getGeneratedType(domainName, versionSet.first()); - sb.append(Utils.createSpaces(indentSize) + "public " + codeType + " " + - field.getName() + "_" + (domainCntr++) + "; // AMQP Version(s): " + versionSet + - CR); - } - return sb.toString(); - } - - protected String generateIndexInitializer(String mapName, AmqpOrdinalVersionMap indexMap, int indentSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - - Iterator<Integer> iItr = indexMap.keySet().iterator(); - while (iItr.hasNext()) - { - int index = iItr.next(); - AmqpVersionSet versionSet = indexMap.get(index); - Iterator<AmqpVersion> vItr = versionSet.iterator(); - while (vItr.hasNext()) - { - AmqpVersion version = vItr.next(); - sb.append(indent + mapName + "( (byte) " + version.getMajor() + ", (byte) " + version.getMinor() + ", " + index + ");" + CR); - } - } - return sb.toString(); - } - - protected String generateRegistry(AmqpModel model, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - - for (String className : model.getClassMap().keySet()) - { - AmqpClass thisClass = model.getClassMap().get(className); - for (String methodName : thisClass.getMethodMap().keySet()) - { - AmqpMethod method = thisClass.getMethodMap().get(methodName); - for (AmqpVersion version : model.getVersionSet()) - { - // Find class and method index for this version (if it exists) - try - { - int classIndex = findIndex(thisClass.getIndexMap(), version); - int methodIndex = findIndex(method.getIndexMap(), version); - sb.append(indent + "registerMethod(" + CR); - sb.append(indent + tab + "(short)" + classIndex + - ", (short)" + methodIndex + ", (byte)" + version.getMajor() + - ", (byte)" + version.getMinor() + ", " + CR); - sb.append(indent + tab + Utils.firstUpper(thisClass.getName()) + - Utils.firstUpper(method.getName()) + "Body.getFactory());" + CR); - } - catch (Exception e) - { - } // Ignore - } - } - } - return sb.toString(); - } - - protected int findIndex(TreeMap<Integer, AmqpVersionSet> map, AmqpVersion version) - { - Iterator<Integer> iItr = map.keySet().iterator(); - while (iItr.hasNext()) - { - int index = iItr.next(); - AmqpVersionSet versionSet = map.get(index); - if (versionSet.contains(version)) - { - return index; - } - } - throw new IllegalArgumentException("Index not found"); - } - - // Methods for AmqpConstants class - - - public String prepareConstantName(String constantName) - { - return upperCaseName(constantName); - } - - - protected String generateConstantGetMethods(AmqpConstantSet constantSet, - int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - - for (AmqpConstant constant : constantSet.getContstants()) - { - - if (constant.isVersionConsistent(constantSet.getVersionSet())) - { - // return a constant - String value = constant.firstKey(); - if (Utils.containsOnlyDigits(value)) - { - sb.append(indent + "public static final int " + constant.getName() + " = " + - constant.firstKey() + ";" + CR); - } - else if (Utils.containsOnlyDigitsAndDecimal(value)) - { - sb.append(indent + "public static double " + constant.getName() + " = " + - constant.firstKey() + "; " + CR); - } - else - { - sb.append(indent + "public static String " + constant.getName() + " = " + - constant.firstKey() + "\"; " + CR); - - } - sb.append(CR); - } - else - { - // Return version-specific constant - sb.append(generateVersionDependentGet(constant, "String", "", "\"", "\"", indentSize, tabSize)); - sb.append(generateVersionDependentGet(constant, "int", "AsInt", "", "", indentSize, tabSize)); - sb.append(generateVersionDependentGet(constant, "double", "AsDouble", "(double)", "", indentSize, tabSize)); - sb.append(CR); - } - } - return sb.toString(); - } - - protected String generateVersionDependentGet(AmqpConstant constant, - String methodReturnType, String methodNameSuffix, String returnPrefix, String returnPostfix, - int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - sb.append(indent + "public static " + methodReturnType + " " + constant.getName() + - methodNameSuffix + "(byte major, byte minor) throws AMQProtocolVersionException" + CR); - sb.append(indent + "{" + CR); - boolean first = true; - Iterator<String> sItr = constant.keySet().iterator(); - while (sItr.hasNext()) - { - String value = sItr.next(); - AmqpVersionSet versionSet = constant.get(value); - sb.append(indent + tab + (first ? "" : "else ") + "if (" + generateVersionCheck(versionSet) + - ")" + CR); - sb.append(indent + tab + "{" + CR); - if (methodReturnType.compareTo("int") == 0 && !Utils.containsOnlyDigits(value)) - { - sb.append(generateConstantDeclarationException(constant.getName(), methodReturnType, - indentSize + (2 * tabSize), tabSize)); - } - else if (methodReturnType.compareTo("double") == 0 && !Utils.containsOnlyDigitsAndDecimal(value)) - { - sb.append(generateConstantDeclarationException(constant.getName(), methodReturnType, - indentSize + (2 * tabSize), tabSize)); - } - else - { - sb.append(indent + tab + tab + "return " + returnPrefix + value + returnPostfix + ";" + CR); - } - sb.append(indent + tab + "}" + CR); - first = false; - } - sb.append(indent + tab + "else" + CR); - sb.append(indent + tab + "{" + CR); - sb.append(indent + tab + tab + "throw new AMQProtocolVersionException(\"Constant \\\"" + - constant.getName() + "\\\" \" +" + CR); - sb.append(indent + tab + tab + tab + - "\"is undefined for AMQP version \" + major + \"-\" + minor + \".\");" + CR); - sb.append(indent + tab + "}" + CR); - sb.append(indent + "}" + CR); - return sb.toString(); - } - - protected String generateConstantDeclarationException(String name, String methodReturnType, - int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - sb.append(indent + "throw new AMQProtocolVersionException(\"Constant \\\"" + - name + "\\\" \" +" + CR); - sb.append(indent + tab + "\"cannot be converted to type " + methodReturnType + - " for AMQP version \" + major + \"-\" + minor + \".\");" + CR); - return sb.toString(); - } - - // Methods for MessageBody classes - protected String generateMbGetMethod(String codeType, AmqpField field, - AmqpVersionSet versionSet, int indentSize, int tabSize, boolean nextFlag) - { - return Utils.createSpaces(indentSize) + "public " + codeType + " get" + - Utils.firstUpper(field.getName()) + "() { return " + field.getName() + "; }" + - CR; - } - - protected String generateMbMangledGetMethod(AmqpField field, int indentSize, - int tabSize, boolean nextFlag) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(CR); - sb.append(indent + "public <T> T get" + Utils.firstUpper(field.getName()) + - "(Class<T> classObj) throws AMQProtocolVersionException" + CR); - sb.append(indent + "{" + CR); - Iterator<String> dItr = field.getDomainMap().keySet().iterator(); - int domainCntr = 0; - while (dItr.hasNext()) - { - String domainName = dItr.next(); - AmqpVersionSet versionSet = field.getDomainMap().get(domainName); - String codeType = getGeneratedType(domainName, versionSet.first()); - sb.append(indent + tab + "if (classObj.equals(" + codeType + - ".class)) // AMQP Version(s): " + versionSet + CR); - sb.append(indent + tab + tab + "return (T)(Object)" + field.getName() + "_" + - (domainCntr++) + ";" + CR); - } - sb.append(indent + tab + - "throw new AMQProtocolVersionException(\"None of the AMQP versions defines \" +" + - CR + " \"field \\\"" + field.getName() + - "\\\" as domain \\\"\" + classObj.getName() + \"\\\".\");" + CR); - sb.append(indent + "}" + CR); - sb.append(CR); - return sb.toString(); - } - - protected String generateMbParamList(String codeType, AmqpField field, - AmqpVersionSet versionSet, int indentSize, int tabSize, boolean nextFlag) - { - return Utils.createSpaces(indentSize) + codeType + " " + field.getName() + - (nextFlag ? "," : "") + " // AMQP version(s): " + versionSet + CR; - } - - - protected String generateMbPassedParamList(String codeType, AmqpField field, - AmqpVersionSet versionSet, int indentSize, int tabSize, boolean nextFlag) - { - return Utils.createSpaces(indentSize) + field.getName() + - (nextFlag ? "," : "") + " // AMQP version(s): " + versionSet + CR; - } - - - protected String generateMbMangledParamList(AmqpField field, int indentSize, - int tabSize, boolean nextFlag) - { - StringBuffer sb = new StringBuffer(); - Iterator<String> dItr = field.getDomainMap().keySet().iterator(); - int domainCntr = 0; - while (dItr.hasNext()) - { - String domainName = dItr.next(); - AmqpVersionSet versionSet = field.getDomainMap().get(domainName); - String codeType = getGeneratedType(domainName, versionSet.first()); - sb.append(Utils.createSpaces(indentSize) + codeType + " " + field.getName() + "_" + - (domainCntr++) + (nextFlag ? "," : "") + " // AMQP version(s): " + - versionSet + CR); - } - return sb.toString(); - } - - protected String generateMbMangledPassedParamList(AmqpField field, int indentSize, - int tabSize, boolean nextFlag) - { - StringBuffer sb = new StringBuffer(); - Iterator<String> dItr = field.getDomainMap().keySet().iterator(); - int domainCntr = 0; - while (dItr.hasNext()) - { - String domainName = dItr.next(); - AmqpVersionSet versionSet = field.getDomainMap().get(domainName); - sb.append(Utils.createSpaces(indentSize) + field.getName() + "_" + - (domainCntr++) + (nextFlag ? "," : "") + " // AMQP version(s): " + - versionSet + CR); - } - return sb.toString(); - } - - - protected String generateMbBodyInit(String codeType, AmqpField field, - AmqpVersionSet versionSet, int indentSize, int tabSize, boolean nextFlag) - { - return Utils.createSpaces(indentSize) + "this." + field.getName() + " = " + field.getName() + - ";" + CR; - } - - protected String generateMbMangledBodyInit(AmqpField field, int indentSize, - int tabSize, boolean nextFlag) - { - StringBuffer sb = new StringBuffer(); - Iterator<String> dItr = field.getDomainMap().keySet().iterator(); - int domainCntr = 0; - while (dItr.hasNext()) - { - dItr.next(); - sb.append(Utils.createSpaces(indentSize) + "this." + field.getName() + "_" + domainCntr + - " = " + field.getName() + "_" + (domainCntr++) + ";" + CR); - } - return sb.toString(); - } - - protected String generateMbFieldSize(String domainType, String fieldName, - int ordinal, int indentSize, int tabSize) - { - StringBuffer sb = new StringBuffer(); - sb.append(Utils.createSpaces(indentSize) + "size += " + - typeMap.get(domainType).size.replaceAll("#", fieldName) + - "; // " + fieldName + ": " + domainType + CR); - return sb.toString(); - } - - protected String generateMbBitArrayFieldSize(List<String> bitFieldList, - int ordinal, int indentSize, int tabSize) - { - StringBuffer sb = new StringBuffer(); - int numBytes = ((bitFieldList.size() - 1) / 8) + 1; - String comment = bitFieldList.size() == 1 ? - bitFieldList.get(0) + ": bit" : - "Combinded bits: " + bitFieldList; - sb.append(Utils.createSpaces(indentSize) + "size += " + - typeMap.get("bit").size.replaceAll("~", String.valueOf(numBytes)) + - "; // " + comment + CR); - return sb.toString(); - } - - protected String generateMbFieldEncode(String domain, String fieldName, - int ordinal, int indentSize, int tabSize) - { - StringBuffer sb = new StringBuffer(); - sb.append(Utils.createSpaces(indentSize) + - typeMap.get(domain).encodeExpression.replaceAll("#", fieldName) + - "; // " + fieldName + ": " + domain + CR); - return sb.toString(); - } - - protected String generateMbBitFieldEncode(List<String> bitFieldList, - int ordinal, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - - StringBuilder sb = new StringBuilder(); - int i = 0; - while (i < bitFieldList.size()) - { - - StringBuilder line = new StringBuilder(); - - for (int j = 0; i < bitFieldList.size() && j < 8; i++, j++) - { - if (j != 0) - { - line.append(", "); - } - line.append(bitFieldList.get(i)); - } - - sb.append(indent + - typeMap.get("bit").encodeExpression.replaceAll("#", line.toString()) + ";" + CR); - } - return sb.toString(); - } - - protected String generateMbFieldDecode(String domain, String fieldName, - int ordinal, int indentSize, int tabSize) - { - StringBuffer sb = new StringBuffer(); - sb.append(Utils.createSpaces(indentSize) + - typeMap.get(domain).decodeExpression.replaceAll("#", fieldName) + - "; // " + fieldName + ": " + domain + CR); - return sb.toString(); - } - - protected String generateMbBitFieldDecode(List<String> bitFieldList, - int ordinal, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - - StringBuilder sb = new StringBuilder(indent); - sb.append("byte packedValue;"); - sb.append(CR); - - // RG HERE! - - int i = 0; - while (i < bitFieldList.size()) - { - sb.append(indent + "packedValue = EncodingUtils.readByte(buffer);" + CR); - - for (int j = 0; i < bitFieldList.size() && j < 8; i++, j++) - { - sb.append(indent + bitFieldList.get(i) + " = ( packedValue & (byte) (1 << " + j + ") ) != 0;" + CR); - } - } - return sb.toString(); - } - - protected String generateMbFieldToString(String domain, String fieldName, - int ordinal, int indentSize, int tabSize) - { - StringBuffer sb = new StringBuffer(); - sb.append(Utils.createSpaces(indentSize) + - "buf.append(\" " + fieldName + ": \" + " + fieldName + ");" + CR); - return sb.toString(); - } - - protected String generateMbBitFieldToString(List<String> bitFieldList, - int ordinal, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - for (int i = 0; i < bitFieldList.size(); i++) - { - String bitFieldName = bitFieldList.get(i); - sb.append(indent + "buf.append(\" " + bitFieldName + ": \" + " + bitFieldName + - ");" + CR); - } - return sb.toString(); - } - - // Methods for PropertyContentHeader classes - - protected String generatePchClearMethod(String codeType, AmqpField field, - AmqpVersionSet versionSet, int indentSize, int tabSize, boolean nextFlag) - { - // This is one case where the ordinal info is the only significant factor, - // the domain info plays no part. Defer to the mangled version; the code would be - // identical anyway... - return generatePchMangledClearMethod(field, indentSize, tabSize, nextFlag); - } - - protected String generatePchMangledClearMethod(AmqpField field, int indentSize, - int tabSize, boolean nextFlag) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - sb.append(indent + "public void clear" + Utils.firstUpper(field.getName()) + - "()" + CR); - sb.append(indent + "{" + CR); - - // If there is more than one ordinal for this field or the ordinal does not - // apply to all known versions, then we need to generate version checks so - // we know which fieldProperty to clear. - if (field.getOrdinalMap().size() == 1 && - field.getOrdinalMap().get(field.getOrdinalMap().firstKey()).size() == field.getVersionSet().size()) - { - int ordinal = field.getOrdinalMap().firstKey(); - sb.append(indent + tab + "clearEncodedForm();" + CR); - sb.append(indent + tab + "propertyFlags[" + ordinal + "] = false;" + CR); - } - else - { - Iterator<Integer> oItr = field.getOrdinalMap().keySet().iterator(); - while (oItr.hasNext()) - { - int ordinal = oItr.next(); - AmqpVersionSet versionSet = field.getOrdinalMap().get(ordinal); - sb.append(indent + tab); - if (ordinal != field.getOrdinalMap().firstKey()) - { - sb.append("else "); - } - sb.append("if ("); - sb.append(generateVersionCheck(versionSet)); - sb.append(")" + CR); - sb.append(indent + tab + "{" + CR); - sb.append(indent + tab + tab + "clearEncodedForm();" + CR); - sb.append(indent + tab + tab + "propertyFlags[" + ordinal + "] = false;" + CR); - sb.append(indent + tab + "}" + CR); - } - } - sb.append(indent + "}" + CR); - sb.append(CR); - return sb.toString(); - } - - protected String generatePchGetMethod(String codeType, AmqpField field, - AmqpVersionSet versionSet, int indentSize, int tabSize, boolean nextFlag) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(indent + "public " + codeType + " get" + - Utils.firstUpper(field.getName()) + "()" + CR); - sb.append(indent + "{" + CR); - sb.append(indent + tab + "decodeIfNecessary();" + CR); - sb.append(indent + tab + "return " + field.getName() + ";" + CR); - sb.append(indent + "}" + CR); - sb.append(CR); - return sb.toString(); - } - - protected String generatePchMangledGetMethod(AmqpField field, int indentSize, - int tabSize, boolean nextFlag) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(indent + "public <T> T get" + - Utils.firstUpper(field.getName()) + - "(Class<T> classObj) throws AMQProtocolVersionException" + CR); - sb.append(indent + "{" + CR); - Iterator<String> dItr = field.getDomainMap().keySet().iterator(); - int domainCntr = 0; - while (dItr.hasNext()) - { - String domainName = dItr.next(); - AmqpVersionSet versionSet = field.getDomainMap().get(domainName); - String codeType = getGeneratedType(domainName, versionSet.first()); - sb.append(indent + tab + "if (classObj.equals(" + codeType + - ".class)) // AMQP Version(s): " + versionSet + CR); - sb.append(indent + tab + "{" + CR); - sb.append(indent + tab + tab + "decodeIfNecessary();" + CR); - sb.append(indent + tab + tab + "return (T)(Object)" + field.getName() + "_" + - (domainCntr++) + ";" + CR); - sb.append(indent + tab + "}" + CR); - } - sb.append(indent + tab + - "throw new AMQProtocolVersionException(\"None of the AMQP versions defines \" +" + - CR + " \"field \\\"" + field.getName() + - "\\\" as domain \\\"\" + classObj.getName() + \"\\\".\");" + CR); - sb.append(indent + "}" + CR); - sb.append(CR); - return sb.toString(); - } - - protected String generatePchSetMethod(String codeType, AmqpField field, - AmqpVersionSet versionSet, int indentSize, int tabSize, boolean nextFlag) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - sb.append(indent + "public void set" + Utils.firstUpper(field.getName()) + - "(" + codeType + " " + field.getName() + ")" + CR); - sb.append(indent + "{" + CR); - - // If there is more than one ordinal for this field or the ordinal does not - // apply to all known versions, then we need to generate version checks so - // we know which fieldProperty to clear. - if (field.getOrdinalMap().size() == 1 && - field.getOrdinalMap().get(field.getOrdinalMap().firstKey()).size() == field.getVersionSet().size()) - { - int ordinal = field.getOrdinalMap().firstKey(); - sb.append(indent + tab + "clearEncodedForm();" + CR); - sb.append(indent + tab + "propertyFlags[" + ordinal + "] = true;" + CR); - sb.append(indent + tab + "this." + field.getName() + " = " + field.getName() + ";" + CR); - } - else - { - Iterator<Integer> oItr = field.getOrdinalMap().keySet().iterator(); - while (oItr.hasNext()) - { - int ordinal = oItr.next(); - AmqpVersionSet oVersionSet = field.getOrdinalMap().get(ordinal); - sb.append(indent + tab); - if (ordinal != field.getOrdinalMap().firstKey()) - { - sb.append("else "); - } - sb.append("if ("); - sb.append(generateVersionCheck(oVersionSet)); - sb.append(")" + CR); - sb.append(indent + tab + "{" + CR); - sb.append(indent + tab + tab + "clearEncodedForm();" + CR); - sb.append(indent + tab + tab + "propertyFlags[" + ordinal + "] = true;" + CR); - sb.append(indent + tab + tab + "this." + field.getName() + " = " + field.getName() + ";" + CR); - sb.append(indent + tab + "}" + CR); - } - } - sb.append(indent + "}" + CR); - sb.append(CR); - return sb.toString(); - } - - protected String generatePchMangledSetMethod(AmqpField field, int indentSize, - int tabSize, boolean nextFlag) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - - Iterator<String> dItr = field.getDomainMap().keySet().iterator(); - int domainCntr = 0; - while (dItr.hasNext()) - { - String domainName = dItr.next(); - AmqpVersionSet versionSet = field.getDomainMap().get(domainName); - String codeType = getGeneratedType(domainName, versionSet.first()); - - // Find ordinal with matching version - AmqpVersionSet commonVersionSet = new AmqpVersionSet(); - Iterator<Integer> oItr = field.getOrdinalMap().keySet().iterator(); - while (oItr.hasNext()) - { - int ordinal = oItr.next(); - AmqpVersionSet oVersionSet = field.getOrdinalMap().get(ordinal); - Iterator<AmqpVersion> vItr = oVersionSet.iterator(); - boolean first = true; - while (vItr.hasNext()) - { - AmqpVersion thisVersion = vItr.next(); - if (versionSet.contains(thisVersion)) - { - commonVersionSet.add(thisVersion); - } - } - if (!commonVersionSet.isEmpty()) - { - sb.append(indent + "public void set" + Utils.firstUpper(field.getName()) + - "(" + codeType + " " + field.getName() + ")" + CR); - sb.append(indent + "{" + CR); - sb.append(indent + tab); - if (!first) - { - sb.append("else "); - } - sb.append("if ("); - sb.append(generateVersionCheck(commonVersionSet)); - sb.append(")" + CR); - sb.append(indent + tab + "{" + CR); - sb.append(indent + tab + tab + "clearEncodedForm();" + CR); - sb.append(indent + tab + tab + "propertyFlags[" + ordinal + "] = true;" + CR); - sb.append(indent + tab + tab + "this." + field.getName() + "_" + (domainCntr++) + - " = " + field.getName() + ";" + CR); - sb.append(indent + tab + "}" + CR); - sb.append(indent + "}" + CR); - sb.append(CR); - first = false; - } - } - } - return sb.toString(); - } - - protected String generatePchFieldSize(String domainType, String fieldName, - int ordinal, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(indent + "if (propertyFlags[" + ordinal + "]) // " + - fieldName + ": " + domainType + CR); - sb.append(indent + Utils.createSpaces(tabSize) + "size += " + - typeMap.get(domainType).size.replaceAll("#", fieldName) + ";" + CR); - sb.append(CR); - return sb.toString(); - } - - protected String generatePchBitArrayFieldSize(List<String> bitFieldList, - int ordinal, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - String comment = bitFieldList.size() == 1 ? - bitFieldList.get(0) + ": bit" : - "Combinded bits: " + bitFieldList; - StringBuffer sb = new StringBuffer(); - - if (bitFieldList.size() == 1) // single bit - { - sb.append(indent + "if (propertyFlags[" + (ordinal - 1) + "]) // " + comment + CR); - sb.append(indent + tab + "size += " + - typeMap.get("bit").size.replaceAll("~", "1") + ";" + CR); - } - else // multiple bits - up to 8 are combined into one byte - { - String bitCntrName = "bitCntr_" + ordinal; - int startOrdinal = ordinal - bitFieldList.size(); - sb.append(indent + "// " + comment + CR); - sb.append(indent + "int " + bitCntrName + " = 0;" + CR); - sb.append(indent + "for (int i=" + startOrdinal + "; i<" + ordinal + "; i++)" + CR); - sb.append(indent + "{" + CR); - sb.append(indent + tab + "if (propertyFlags[i])" + CR); - sb.append(indent + tab + tab + bitCntrName + "++;" + CR); - sb.append(indent + "}" + CR); - sb.append(indent + "size += " + - typeMap.get("bit").size.replaceAll("~", bitCntrName + - " > 0 ? ((" + bitCntrName + " - 1) / 8) + 1 : 0") + ";" + CR); - } - sb.append(CR); - return sb.toString(); - } - - protected String generatePchFieldEncode(String domainType, String fieldName, - int ordinal, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - sb.append(indent + "if (propertyFlags[" + ordinal + "]) // " + fieldName + ": " + - domainType + CR); - sb.append(indent + Utils.createSpaces(tabSize) + - typeMap.get(domainType).encodeExpression.replaceAll("#", fieldName) + ";" + CR); - sb.append(CR); - return sb.toString(); - } - - protected String generatePchBitFieldEncode(List<String> bitFieldList, - int ordinal, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - String comment = bitFieldList.size() == 1 ? - bitFieldList.get(0) + ": bit" : - "Combinded bits: " + bitFieldList; - StringBuffer sb = new StringBuffer(); - - if (bitFieldList.size() == 1) // single bit - { - sb.append(indent + "if (propertyFlags[" + (ordinal - 1) + "]) // " + - bitFieldList.get(0) + ": bit" + CR); - sb.append(indent + tab + typeMap.get("bit").encodeExpression.replaceAll("#", - "new boolean[] {" + bitFieldList.get(0) + "}") + ";" + CR); - } - else // multiple bits - up to 8 are combined into one byte - { - int startOrdinal = ordinal - bitFieldList.size(); - String bitCntrName = "bitCntr" + startOrdinal; - sb.append(indent + "// " + comment + CR); - sb.append(indent + "int " + bitCntrName + " = 0;" + CR); - sb.append(indent + "for (int i=" + startOrdinal + "; i<=" + (ordinal - 1) + "; i++)" + CR); - sb.append(indent + "{" + CR); - sb.append(indent + tab + "if (propertyFlags[i])" + CR); - sb.append(indent + tab + tab + bitCntrName + "++;" + CR); - sb.append(indent + "}" + CR); - sb.append(indent + "if (" + bitCntrName + " > 0) // Are any of the property bits set?" + CR); - sb.append(indent + "{" + CR); - sb.append(indent + tab + "boolean[] fullBitArray = new boolean[] { "); - for (int i = 0; i < bitFieldList.size(); i++) - { - if (i != 0) - { - sb.append(", "); - } - sb.append(bitFieldList.get(i)); - } - sb.append(" };" + CR); - sb.append(indent + tab + "boolean[] flaggedBitArray = new boolean[" + bitCntrName + - "];" + CR); - sb.append(indent + tab + bitCntrName + " = 0;" + CR); - sb.append(indent + tab + "for (int i=" + startOrdinal + "; i<=" + (ordinal - 1) + - "; i++)" + CR); - sb.append(indent + tab + "{" + CR); - sb.append(indent + tab + tab + "if (propertyFlags[i])" + CR); - sb.append(indent + tab + tab + tab + "flaggedBitArray[" + bitCntrName + - "++] = fullBitArray[i];" + CR); - sb.append(indent + tab + "}" + CR); - sb.append(indent + tab + typeMap.get("bit").encodeExpression.replaceAll("#", - "flaggedBitArray") + ";" + CR); - sb.append(indent + "}" + CR); - } - sb.append(CR); - return sb.toString(); - } - - protected String generatePchFieldDecode(String domainType, String fieldName, - int ordinal, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - sb.append(indent + "if (propertyFlags[" + ordinal + "]) // " + fieldName + ": " + - domainType + CR); - sb.append(indent + Utils.createSpaces(tabSize) + - typeMap.get(domainType).decodeExpression.replaceAll("#", fieldName) + ";" + CR); - sb.append(CR); - return sb.toString(); - } - - protected String generatePchBitFieldDecode(List<String> bitFieldList, - int ordinal, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - String comment = bitFieldList.size() == 1 ? - bitFieldList.get(0) + ": bit" : - "Combinded bits: " + bitFieldList; - StringBuffer sb = new StringBuffer(); - - if (bitFieldList.size() == 1) // single bit - { - sb.append(indent + "if (propertyFlags[" + (ordinal - 1) + "]) // " + - bitFieldList.get(0) + ": bit" + CR); - sb.append(indent + "{" + CR); - sb.append(indent + tab + typeMap.get("bit").decodeExpression.replaceAll("#", - "boolean[] flaggedBitArray") + ";" + CR); - sb.append(indent + tab + bitFieldList.get(0) + " = flaggedBitArray[0];" + CR); - sb.append(indent + "}" + CR); - } - else // multiple bits - up to 8 are combined into one byte - { - int startOrdinal = ordinal - bitFieldList.size(); - String bitCntr = "bitCntr" + startOrdinal; - sb.append(indent + "// " + comment + CR); - sb.append(indent + "int " + bitCntr + " = 0;" + CR); - sb.append(indent + "for (int i=" + startOrdinal + "; i<=" + (ordinal - 1) + "; i++)" + CR); - sb.append(indent + "{" + CR); - sb.append(indent + tab + "if (propertyFlags[i])" + CR); - sb.append(indent + tab + tab + bitCntr + "++;" + CR); - sb.append(indent + "}" + CR); - sb.append(indent + "if (" + bitCntr + " > 0) // Are any of the property bits set?" + CR); - sb.append(indent + "{" + CR); - sb.append(indent + tab + typeMap.get("bit").decodeExpression.replaceAll("#", - "boolean[] flaggedBitArray") + ";" + CR); - sb.append(indent + tab + bitCntr + " = 0;" + CR); - for (int i = 0; i < bitFieldList.size(); i++) - { - sb.append(indent + tab + "if (propertyFlags[" + (startOrdinal + i) + "])" + CR); - sb.append(indent + tab + tab + bitFieldList.get(i) + " = flaggedBitArray[" + - bitCntr + "++];" + CR); - } - sb.append(indent + "}" + CR); - } - - sb.append(CR); - return sb.toString(); - } - - protected String generatePchGetPropertyFlags(String domainType, String fieldName, - int ordinal, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - int word = ordinal / 15; - int bit = 15 - (ordinal % 15); - sb.append(indent + "if (propertyFlags[" + ordinal + "]) // " + fieldName + ": " + - domainType + CR); - sb.append(indent + tab + "compactPropertyFlags[" + word + "] |= (1 << " + - bit + ");" + CR); - sb.append(CR); - return sb.toString(); - } - - protected String generatePchBitGetPropertyFlags(List<String> bitFieldList, - int ordinal, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - int startOrdinal = ordinal - bitFieldList.size(); - - for (int i = 0; i < bitFieldList.size(); i++) - { - int thisOrdinal = startOrdinal + i; - int word = thisOrdinal / 15; - int bit = 15 - (thisOrdinal % 15); - sb.append(indent + "if (propertyFlags[" + thisOrdinal + "])" + CR); - sb.append(indent + tab + "compactPropertyFlags[" + word + - "] |= (1 << " + bit + ");" + CR); - } - - sb.append(CR); - return sb.toString(); - } - - protected String generatePchSetPropertyFlags(String domainType, String fieldName, - int ordinal, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - int word = ordinal / 15; - int bit = 15 - (ordinal % 15); - sb.append(indent + "propertyFlags[" + ordinal + "] = (compactPropertyFlags[" + - word + "] & (1 << " + bit + ")) > 0;" + CR); - return sb.toString(); - } - - protected String generatePchBitSetPropertyFlags(List<String> bitFieldList, - int ordinal, int indentSize, int tabSize) - { - String indent = Utils.createSpaces(indentSize); - StringBuffer sb = new StringBuffer(); - int startOrdinal = ordinal - bitFieldList.size(); - - for (int i = 0; i < bitFieldList.size(); i++) - { - int thisOrdinal = startOrdinal + i; - int word = thisOrdinal / 15; - int bit = 15 - (thisOrdinal % 15); - sb.append(indent + "propertyFlags[" + thisOrdinal + "] = (compactPropertyFlags[" + - word + "] & (1 << " + bit + ")) > 0;" + CR); - } - return sb.toString(); - } - - private String generatePchPropertyFlagsDeclare() - { - return "private boolean[] propertyFlags;"; - } - - private String generatePchPropertyFlagsInitializer(int totNumFields) - { - return "propertyFlags = new boolean[" + totNumFields + "];"; - } - - private String generatePchCompactPropertyFlagsInitializer(AmqpClass thisClass, int indentSize, - int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - Iterator<AmqpVersion> vItr = thisClass.getVersionSet().iterator(); - while (vItr.hasNext()) - { - AmqpVersion version = vItr.next(); - int numBytes = ((thisClass.getFieldMap().getNumFields(version) - 1) / 15) + 1; - - sb.append(indent); - if (!version.equals(thisClass.getVersionSet().first())) - { - sb.append("else "); - } - sb.append("if ( major == " + version.getMajor() + " && minor == " + - version.getMinor() + " )" + CR); - sb.append(indent + tab + "compactPropertyFlags = new int[] { "); - for (int i = 0; i < numBytes; i++) - { - if (i != 0) - { - sb.append(", "); - } - sb.append(i < numBytes - 1 ? "1" : "0"); // Set the "continue" flag where required - } - sb.append(" };" + CR); - } - return sb.toString(); - } - - private String generatePchCompactPropertyFlagsCheck(AmqpClass thisClass, int indentSize, - int tabSize) - { - String indent = Utils.createSpaces(indentSize); - String tab = Utils.createSpaces(tabSize); - StringBuffer sb = new StringBuffer(); - Iterator<AmqpVersion> vItr = thisClass.getVersionSet().iterator(); - while (vItr.hasNext()) - { - AmqpVersion version = vItr.next(); - int numFields = thisClass.getFieldMap().getNumFields(version); - int numBytes = ((numFields - 1) / 15) + 1; - - sb.append(indent); - if (!version.equals(thisClass.getVersionSet().first())) - { - sb.append("else "); - } - sb.append("if ( major == " + version.getMajor() + " && minor == " + - version.getMinor() + " && compactPropertyFlags.length != " + numBytes + " )" + CR); - sb.append(indent + tab + - "throw new AMQProtocolVersionException(\"Property flag array size mismatch:\" +" + CR); - sb.append(indent + tab + tab + "\"(Size found: \" + compactPropertyFlags.length +" + CR); - sb.append(indent + tab + tab + "\") Version " + version + " has " + numFields + - " fields which requires an int array of size " + numBytes + ".\");" + CR); - } - return sb.toString(); - } - - private String generateVersionCheck(AmqpVersionSet v) - { - StringBuffer sb = new StringBuffer(); - AmqpVersion[] versionArray = new AmqpVersion[v.size()]; - v.toArray(versionArray); - for (int i = 0; i < versionArray.length; i++) - { - if (i != 0) - { - sb.append(" || "); - } - if (versionArray.length > 1) - { - sb.append("("); - } - sb.append("major == (byte)" + versionArray[i].getMajor() + " && minor == (byte)" + - versionArray[i].getMinor()); - if (versionArray.length > 1) - { - sb.append(")"); - } - } - return sb.toString(); - } - - private String camelCaseName(String name, boolean upperFirstFlag) - { - StringBuffer ccn = new StringBuffer(); - String[] toks = name.split("[-_.\\ ]"); - for (int i = 0; i < toks.length; i++) - { - StringBuffer b = new StringBuffer(toks[i]); - if (upperFirstFlag || i > 0) - { - b.setCharAt(0, Character.toUpperCase(toks[i].charAt(0))); - } - ccn.append(b); - } - return ccn.toString(); - } - - - private String upperCaseName(String name) - { - StringBuffer ccn = new StringBuffer(); - String[] toks = name.split("[-_.\\ ]"); - for (int i = 0; i < toks.length; i++) - { - if (i != 0) - { - ccn.append('_'); - } - ccn.append(toks[i].toUpperCase()); - - - } - return ccn.toString(); - } - - - public static Factory<JavaGenerator> _factoryInstance = new Factory<JavaGenerator>() - { - - public JavaGenerator newInstance() - { - return new JavaGenerator(); - } - }; - - public static Factory<JavaGenerator> getFactory() - { - return _factoryInstance; - } - - - void processModelTemplate(NamedTemplate template, AmqpVersion version) - { - //To change body of implemented methods use File | Settings | File Templates. - } - - void processClassTemplate(NamedTemplate template, AmqpClass amqpClass, AmqpVersion version) - { - //To change body of implemented methods use File | Settings | File Templates. - } - - void processMethodTemplate(NamedTemplate template, AmqpClass amqpClass, AmqpMethod amqpMethod, AmqpVersion version) - { - //To change body of implemented methods use File | Settings | File Templates. - } - - void processFieldTemplate(NamedTemplate template, AmqpClass amqpClass, AmqpMethod amqpMethod, AmqpField amqpField, AmqpVersion version) - { - //To change body of implemented methods use File | Settings | File Templates. - } - - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/LanguageConverter.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/LanguageConverter.java deleted file mode 100644 index 5e692d86e7..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/LanguageConverter.java +++ /dev/null @@ -1,42 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -public interface LanguageConverter -{ - -// public AmqpDomainMap getDomainMap(); -// public AmqpConstantSet getConstantSet(); -// public AmqpModel getModel(); - - // - public String prepareClassName(String className); - - public String prepareMethodName(String methodName); - - public String prepareDomainName(String domainName); - - public String getDomainType(String domainName, AmqpVersion version); - - public String getGeneratedType(String domainName, AmqpVersion version); - - public String prepareConstantName(String constantName); -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/Main.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/Main.java deleted file mode 100644 index c0584f7ca7..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/Main.java +++ /dev/null @@ -1,301 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import org.apache.velocity.app.Velocity; -import org.w3c.dom.Document; -import org.w3c.dom.Node; -import org.xml.sax.SAXException; - -import javax.xml.parsers.DocumentBuilder; -import javax.xml.parsers.DocumentBuilderFactory; -import javax.xml.parsers.ParserConfigurationException; -import java.io.File; -import java.io.IOException; -import java.lang.reflect.InvocationTargetException; -import java.util.ArrayList; -import java.util.Properties; - -public class Main -{ - private static final String DEFAULT_OUTPUT_DIR = ".." + Utils.FILE_SEPARATOR + "gen"; - private static final String DEFAULT_TEMPLATE_DIR_BASE = ".." + Utils.FILE_SEPARATOR; - - private enum GeneratedLanguage - { - CPP(".cpp", CppGenerator.getFactory()), - DOTNET(".net", DotnetGenerator.getFactory()), - JAVA(".java", JavaGenerator.getFactory()); - - private final String _suffix; - private final Generator.Factory _factory; - - - private final String _defaultTemplateDirectory; - - GeneratedLanguage(String suffix, Generator.Factory factory) - { - _suffix = suffix; - _factory = factory; - _defaultTemplateDirectory = DEFAULT_TEMPLATE_DIR_BASE + "templ" + _suffix; - } - - public String getSuffix() - { - return _suffix; - } - - public Generator newGenerator() - { - return _factory.newInstance(); - } - - public String getDefaultTemplateDirectory() - { - return _defaultTemplateDirectory; - } - } - - private Generator generator; - - private String outDir; - private String tmplDir; - private GeneratedLanguage _generatorLang; - private ArrayList<String> xmlFiles; - - public Main() - { - xmlFiles = new ArrayList<String>(); - } - - public void run(String[] args) - throws Exception, - SAXException, - AmqpParseException, - AmqpTypeMappingException, - AmqpTemplateException, - TargetDirectoryException, - IllegalAccessException, - InvocationTargetException, ParserConfigurationException - { - - // 0. Initialize - outDir = DEFAULT_OUTPUT_DIR; - tmplDir = null; - _generatorLang = GeneratedLanguage.CPP; // Default generation language - xmlFiles.clear(); - processArgs(args); - - if (tmplDir == null) - { - tmplDir = _generatorLang.getDefaultTemplateDirectory(); - } - - - generator = _generatorLang.newGenerator(); - generator.setTemplateDirectory(tmplDir); - generator.setOutputDirectory(outDir); - - // 1. Suck in all the XML spec files provided on the command line - analyzeXML(); - - Properties p = new Properties(); - p.setProperty("file.resource.loader.path", tmplDir); - - Velocity.init(p); - - // 2. Load up all templates - generator.initializeTemplates(); - - // 3. Generate output - generator.generate(); - - System.out.println("Files generated: " + generator.getNumberGeneratedFiles()); - System.out.println("Done."); - } - - private void processArgs(String[] args) - { - // Crude but simple... - for (int i = 0; i < args.length; i++) - { - String arg = args[i]; - if (arg.charAt(0) == '-') - { - switch (arg.charAt(1)) - { - case'c': - case'C': - _generatorLang = GeneratedLanguage.CPP; - break; - case'j': - case'J': - _generatorLang = GeneratedLanguage.JAVA; - break; - case'n': - case'N': - _generatorLang = GeneratedLanguage.DOTNET; - break; - case'o': - case'O': - if (++i < args.length) - { - outDir = args[i]; - } - break; - case't': - case'T': - if (++i < args.length) - { - tmplDir = args[i]; - } - break; - } - } - else - { - xmlFiles.add(args[i]); - } - } - } - - private void analyzeXML() - throws IOException, SAXException, AmqpParseException, AmqpTypeMappingException, ParserConfigurationException - { - DocumentBuilder docBuilder = DocumentBuilderFactory.newInstance().newDocumentBuilder(); - - System.out.println("XML files: " + xmlFiles); - for (String filename : xmlFiles) - { - File f = new File(filename); - if (f.exists()) - { - // 1a. Initialize dom - System.out.print(" \"" + filename + "\":"); - Document doc = docBuilder.parse(new File(filename)); - Node amqpNode = Utils.findChild(doc, Utils.ELEMENT_AMQP); - - // 1b. Extract version (major and minor) from the XML file - int major = Utils.getNamedIntegerAttribute(amqpNode, Utils.ATTRIBUTE_MAJOR); - int minor = Utils.getNamedIntegerAttribute(amqpNode, Utils.ATTRIBUTE_MINOR); - AmqpVersion version = new AmqpVersion(major, minor); - System.out.println(" Found version " + version.toString() + "."); - generator.addVersion(version); - generator.addFromNode(amqpNode, version); - - - } - else - { - System.err.println("ERROR: AMQP XML file \"" + filename + "\" not found."); - } - } -// *** DEBUG INFO *** Uncomment bits from this block to see lots of stuff.... -// System.out.println(); -// System.out.println("*** Debug output ***"); -// System.out.println(); -// versionSet.print(System.out, 0, 2); // List of loaded versions -// System.out.println(); -// constants.print(System.out, 0, 2); // List of constants -// System.out.println(); -// domainMap.print(System.out, 0, 2); // List of domains -// System.out.println(); -// model.print(System.out, 0, 2); // Internal version map model -// System.out.println(); -// System.out.println("*** End debug output ***"); -// System.out.println(); - } - - public static void main(String[] args) - { - int exitCode = 1; - // TODO: This is a simple and klunky way of hangling command-line args, and could be improved upon. - if (args.length < 2) - { - usage(); - } - else - { - try - { - new Main().run(args); - exitCode = 0; - } - catch (IOException e) - { - e.printStackTrace(); - } - catch (ParserConfigurationException e) - { - e.printStackTrace(); - } - catch (SAXException e) - { - e.printStackTrace(); - } - catch (AmqpParseException e) - { - e.printStackTrace(); - } - catch (AmqpTypeMappingException e) - { - e.printStackTrace(); - } - catch (AmqpTemplateException e) - { - e.printStackTrace(); - } - catch (TargetDirectoryException e) - { - e.printStackTrace(); - } - catch (IllegalAccessException e) - { - e.printStackTrace(); - } - catch (InvocationTargetException e) - { - e.printStackTrace(); - } - catch (Exception e) - { - e.printStackTrace(); - } - } - System.exit(exitCode); - } - - public static void usage() - { - System.out.println("AMQP XML generator v.0.0"); - System.out.println("Usage: Main -c|-j [-o outDir] [-t tmplDir] XMLfile [XMLfile ...]"); - System.out.println(" where -c: Generate C++."); - System.out.println(" -j: Generate Java."); - System.out.println(" -n: Generate .NET."); - System.out.println(" -o outDir: Use outDir as the output dir (default=\"" + DEFAULT_OUTPUT_DIR + "\")."); - System.out.println(" -t tmplDir: Find templates in tmplDir."); - System.out.println(" Defaults: \"" + GeneratedLanguage.CPP.getDefaultTemplateDirectory() + "\" for C++;"); - System.out.println(" \"" + GeneratedLanguage.JAVA.getDefaultTemplateDirectory() + "\" for java.;"); - System.out.println(" \"" + GeneratedLanguage.DOTNET.getDefaultTemplateDirectory() + "\" for .NET."); - System.out.println(" XMLfile is a space-separated list of AMQP XML files to be parsed."); - } - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/MangledGenerateMethod.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/MangledGenerateMethod.java deleted file mode 100644 index ffeefed900..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/MangledGenerateMethod.java +++ /dev/null @@ -1,26 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -public interface MangledGenerateMethod -{ - String generate(AmqpField field, int indentSize, int tabSize, boolean notLast); -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/NodeAware.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/NodeAware.java deleted file mode 100644 index f832da75ad..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/NodeAware.java +++ /dev/null @@ -1,47 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import org.w3c.dom.Node; - -/** - * @author kpvdr - * Interface allowing the addition of elements from a node in the - * DOM of the AMQP specification. It is used by each of the model - * elements in a recursive fashion to build the model. - */ -public interface NodeAware -{ - /** - * Add a model element from the current DOM node. All model elements must implement - * this interface. If the node contains children that are also a part of the model, - * then this method is called on new instances of those model elements. - * - * @param n Node from which the current model element is to be added. - * @param o Ordinal value of the current model elemet. - * @param v Verion of the DOM from which the node comes. - * @throws AmqpParseException - * @throws AmqpTypeMappingException - * @returns true if a node was added, false if not - */ - public boolean addFromNode(Node n, int o, AmqpVersion v) - throws AmqpParseException, AmqpTypeMappingException; -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/Printable.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/Printable.java deleted file mode 100644 index aa13df7b68..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/Printable.java +++ /dev/null @@ -1,28 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.io.PrintStream; - -public interface Printable -{ - public void print(PrintStream out, int marginSize, int tabSize); -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/SingleVersionClass.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/SingleVersionClass.java deleted file mode 100644 index 8e1af1c551..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/SingleVersionClass.java +++ /dev/null @@ -1,103 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.util.Map; -import java.util.List; -import java.util.ArrayList; -import java.util.Collection; -import java.util.Collections; -import java.util.Comparator; -import java.util.Map.Entry; - - -public class SingleVersionClass -{ - private final int _classId; - - - private final AmqpClass _amqpClass; - private final AmqpVersion _amqpVersion; - private final Generator _generator; - private final List<SingleVersionMethod> _methodList = new ArrayList<SingleVersionMethod>(); - - public SingleVersionClass(AmqpClass amqpClass, AmqpVersion amqpVersion, Generator generator) - { - _amqpClass = amqpClass; - _amqpVersion = amqpVersion; - _generator = generator; - - AmqpOrdinalVersionMap indexMap = amqpClass.getIndexMap(); - int classId = 0; - for(Entry<Integer, AmqpVersionSet> entry : indexMap.entrySet()) - { - if(entry.getValue().contains(_amqpVersion)) - { - classId = entry.getKey(); - break; - } - } - _classId = classId; - - - Collection<AmqpMethod> methods = _amqpClass.getMethodMap().values(); - - for(AmqpMethod amqpMethod : methods) - { - _methodList.add(new SingleVersionMethod(amqpMethod, _amqpVersion, _generator)); - - } - - Collections.sort(_methodList, new Comparator<SingleVersionMethod>(){ - public int compare(SingleVersionMethod method1, SingleVersionMethod method2) - { - return method1.getMethodId() - method2.getMethodId(); - } - }); - - - } - - public int getClassId() - { - return _classId; - } - - public String getName() - { - return _amqpClass.getName(); - } - - - - - - public List<SingleVersionMethod> getMethodList() - { - return _methodList; - } - - - public int getMaximumMethodId() - { - return _methodList.get(_methodList.size()-1).getMethodId(); - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/SingleVersionField.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/SingleVersionField.java deleted file mode 100644 index b795663d15..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/SingleVersionField.java +++ /dev/null @@ -1,68 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - - -public class SingleVersionField -{ - private final AmqpField _field; - private final AmqpVersion _amqpVersion; - private final Generator _generator; - - public SingleVersionField(AmqpField field, AmqpVersion amqpVersion, Generator generator) - { - _field = field; - _amqpVersion = amqpVersion; - _generator = generator; - } - - public String getName() - { - return _field.getName(); - } - - public String getDomain() - { - return _field.getDomain(_amqpVersion); - } - - - public String getDomainType() - { - return _generator.getDomainType(_field.getDomain(_amqpVersion),_amqpVersion); - } - - public String getNativeType() - { - return _generator.getNativeType(getDomainType()); - } - - public String getEncodingType() - { - return _generator.getEncodingType(getDomainType()); - } - - - public int getPosition() - { - return _field.getOrdinal(_amqpVersion); - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/SingleVersionMethod.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/SingleVersionMethod.java deleted file mode 100644 index 59a6d9e28a..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/SingleVersionMethod.java +++ /dev/null @@ -1,154 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.util.Map.Entry; -import java.util.Collection; -import java.util.ArrayList; -import java.util.Collections; -import java.util.Comparator; -import java.util.List; -import java.util.Map; -import java.util.HashMap; - -public class SingleVersionMethod -{ - private final AmqpMethod _amqpMethod; - private final AmqpVersion _amqpVersion; - private final int _methodId; - private final List<SingleVersionField> _fieldList = new ArrayList<SingleVersionField>(); - private final Generator _generator; - private final List<ConsolidatedField> _consolidatedFields = new ArrayList<ConsolidatedField>(); - private final Map<String, ConsolidatedField> _fieldNameToConsolidatedFieldMap = new HashMap<String, ConsolidatedField>(); - - - public SingleVersionMethod(AmqpMethod amqpMethod, AmqpVersion amqpVersion, Generator generator) - { - _amqpMethod = amqpMethod; - _amqpVersion = amqpVersion; - _generator = generator; - - AmqpOrdinalVersionMap indexMap = amqpMethod.getIndexMap(); - int methodId = 0; - for(Entry<Integer, AmqpVersionSet> entry : indexMap.entrySet()) - { - if(entry.getValue().contains(_amqpVersion)) - { - methodId = entry.getKey(); - break; - } - } - _methodId = methodId; - - Collection<AmqpField> fields = _amqpMethod.getFieldMap().values(); - - for(AmqpField field : fields) - { - _fieldList.add(new SingleVersionField(field, _amqpVersion, _generator)); - - } - - Collections.sort(_fieldList, new Comparator<SingleVersionField>(){ - public int compare(SingleVersionField field1, SingleVersionField field2) - { - return field1.getPosition() - field2.getPosition(); - } - }); - - - - ConsolidatedField lastField = null; - int bitfieldNum = 0; - for(SingleVersionField field : _fieldList) - { - String domainType = field.getDomainType(); - if(!domainType.equals("bit")) - { - lastField = new ConsolidatedField(_generator, - field.getName(), - field.getDomainType()); - _consolidatedFields.add(lastField); - } - else if(lastField == null || !lastField.getType().equals("bitfield")) - { - lastField = new ConsolidatedField(_generator, - domainType.equals("bit") ? "bitfield"+bitfieldNum++ : field.getName(), - domainType.equals("bit") ? "bitfield" : field.getDomainType(), - field.getName()); - _consolidatedFields.add(lastField); - } - else - { - lastField.add(field.getName()); - } - _fieldNameToConsolidatedFieldMap.put(field.getName(), lastField); - - } - } - - public int getMethodId() - { - return _methodId; - } - - public String getName() - { - return _amqpMethod.getName(); - } - - public Collection<SingleVersionField> getFieldList() - { - return Collections.unmodifiableCollection(_fieldList); - } - - public List<ConsolidatedField> getConsolidatedFields() - { - return _consolidatedFields; - } - - public String getConsolidatedFieldName(String fieldName) - { - return _fieldNameToConsolidatedFieldMap.get(fieldName).getName(); - } - - public boolean isConsolidated(String fieldName) - { - return _fieldNameToConsolidatedFieldMap.get(fieldName).isConsolidated(); - } - - public int getPositionInBitField(String fieldName) - { - return _fieldNameToConsolidatedFieldMap.get(fieldName).getPosition(fieldName); - } - - - public boolean isServerMethod() - { - return _amqpMethod.isServerMethod(_amqpVersion); - } - - - public boolean isClientMethod() - { - return _amqpMethod.isClientMethod(_amqpVersion); - } - -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/SingleVersionModel.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/SingleVersionModel.java deleted file mode 100644 index 22b416e45a..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/SingleVersionModel.java +++ /dev/null @@ -1,71 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import java.util.Collection; -import java.util.List; -import java.util.ArrayList; -import java.util.Collections; -import java.util.Comparator; - - -public class SingleVersionModel -{ - private final AmqpModel _amqpModel; - private final AmqpVersion _amqpVersion; - private final Generator _generator; - private final List<SingleVersionClass> _classList = new ArrayList<SingleVersionClass>(); - - public SingleVersionModel(AmqpModel amqpModel, AmqpVersion amqpVersion, Generator generator) - { - _amqpModel = amqpModel; - _amqpVersion = amqpVersion; - _generator = generator; - - - Collection<AmqpClass> originalClasses = _amqpModel.getClassMap().values(); - - for(AmqpClass amqpClass : originalClasses) - { - _classList.add(new SingleVersionClass(amqpClass, _amqpVersion, _generator)); - - } - - Collections.sort(_classList, new Comparator<SingleVersionClass>(){ - public int compare(SingleVersionClass amqpClass1, SingleVersionClass amqpClass2) - { - return amqpClass1.getClassId() - amqpClass2.getClassId(); - } - }); - - - } - - public Collection<SingleVersionClass> getClassList() - { - return Collections.unmodifiableCollection(_classList); - } - - public int getMaximumClassId() - { - return _classList.get(_classList.size()-1).getClassId(); - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/TargetDirectoryException.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/TargetDirectoryException.java deleted file mode 100644 index 39ce666288..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/TargetDirectoryException.java +++ /dev/null @@ -1,30 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -@SuppressWarnings("serial") -public class TargetDirectoryException extends RuntimeException -{ - public TargetDirectoryException(String msg) - { - super(msg); - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/Utils.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/Utils.java deleted file mode 100644 index 1cedaeea12..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/Utils.java +++ /dev/null @@ -1,159 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -import org.w3c.dom.Attr; -import org.w3c.dom.NamedNodeMap; -import org.w3c.dom.Node; -import org.w3c.dom.NodeList; - -public class Utils -{ - public final static String FILE_SEPARATOR = System.getProperty("file.separator"); - public final static String LINE_SEPARATOR = System.getProperty("line.separator"); - - public final static String ATTRIBUTE_NAME = "name"; - public final static String ATTRIBUTE_MAJOR = "major"; - public final static String ATTRIBUTE_MINOR = "minor"; - public final static String ATTRIBUTE_INDEX = "index"; - public final static String ATTRIBUTE_LABEL = "label"; - public final static String ATTRIBUTE_SYNCHRONOUS = "synchronous"; - public final static String ATTRIBUTE_CONTENT = "content"; - public final static String ATTRIBUTE_HANDLER = "handler"; - public final static String ATTRIBUTE_DOMAIN = "domain"; - public final static String ATTRIBUTE_VALUE = "value"; - public final static String ATTRIBUTE_TYPE = "type"; // For compatibility with AMQP 8.0 - - public final static String ELEMENT_AMQP = "amqp"; - public final static String ELEMENT_CHASSIS = "chassis"; - public final static String ELEMENT_CLASS = "class"; - public final static String ELEMENT_CODEGEN = "codegen"; - public final static String ELEMENT_CONSTANT = "constant"; - public final static String ELEMENT_DOMAIN = "domain"; - public final static String ELEMENT_METHOD = "method"; - public final static String ELEMENT_FIELD = "field"; - public final static String ELEMENT_VERSION = "version"; - - // Attribute functions - - public static String getNamedAttribute(Node n, String attrName) throws AmqpParseException - { - NamedNodeMap nnm = n.getAttributes(); - if (nnm == null) - { - throw new AmqpParseException("Node \"" + n.getNodeName() + "\" has no attributes."); - } - Attr a = (Attr) nnm.getNamedItem(attrName); - if (a == null) - { - throw new AmqpParseException("Node \"" + n.getNodeName() + "\" has no attribute \"" + attrName + "\"."); - } - return a.getNodeValue(); - } - - public static int getNamedIntegerAttribute(Node n, String attrName) throws AmqpParseException - { - return Integer.parseInt(getNamedAttribute(n, attrName)); - } - - // Element functions - - public static Node findChild(Node n, String eltName) throws AmqpParseException - { - NodeList nl = n.getChildNodes(); - for (int i = 0; i < nl.getLength(); i++) - { - Node cn = nl.item(i); - if (cn.getNodeName().compareTo(eltName) == 0) - { - return cn; - } - } - throw new AmqpParseException("Node \"" + n.getNodeName() + - "\" does not contain child element \"" + eltName + "\"."); - } - - // String functions - - public static String firstUpper(String str) - { - if (!Character.isLetter(str.charAt(0)) || !Character.isLowerCase(str.charAt(0))) - { - return str; - } - StringBuffer sb = new StringBuffer(str); - sb.setCharAt(0, Character.toUpperCase(str.charAt(0))); - return sb.toString(); - } - - public static String firstLower(String str) - { - if (!Character.isUpperCase(str.charAt(0))) - { - return str; - } - StringBuffer sb = new StringBuffer(str); - sb.setCharAt(0, Character.toLowerCase(str.charAt(0))); - return sb.toString(); - } - - public static String createSpaces(int cnt) - { - StringBuffer sb = new StringBuffer(); - for (int i = 0; i < cnt; i++) - { - sb.append(' '); - } - return sb.toString(); - } - - public static boolean containsOnlyDigits(String str) - { - boolean foundNonDigit = false; - for (int i = 0; i < str.length() && !foundNonDigit; i++) - { - if (!Character.isDigit(str.charAt(i))) - { - foundNonDigit = true; - } - } - return !foundNonDigit; - } - - public static boolean containsOnlyDigitsAndDecimal(String str) - { - boolean foundNonDigit = false; - int decimalCntr = 0; - for (int i = 0; i < str.length() && !foundNonDigit && decimalCntr < 2; i++) - { - char ch = str.charAt(i); - if (!(Character.isDigit(ch) || ch == '.')) - { - foundNonDigit = true; - } - else if (ch == '.') - { - decimalCntr++; - } - } - return !foundNonDigit && decimalCntr < 2; - } -} diff --git a/qpid/java/common/gentools/src/org/apache/qpid/gentools/VersionConsistencyCheck.java b/qpid/java/common/gentools/src/org/apache/qpid/gentools/VersionConsistencyCheck.java deleted file mode 100644 index a9cdd56e88..0000000000 --- a/qpid/java/common/gentools/src/org/apache/qpid/gentools/VersionConsistencyCheck.java +++ /dev/null @@ -1,26 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.gentools; - -public interface VersionConsistencyCheck -{ - public boolean isVersionConsistent(AmqpVersionSet globalVersionSet); -} diff --git a/qpid/java/common/pom.xml b/qpid/java/common/pom.xml index 4ba6713a6c..3ebb0098e0 100644 --- a/qpid/java/common/pom.xml +++ b/qpid/java/common/pom.xml @@ -111,7 +111,6 @@ <target> <ant antfile="build-generate-sources.xml"> <reference torefid="source.generation.classpathref" refid="maven.plugin.classpath" /> - <property name="gentools.classes" value="${project.build.directory}/gentools-classes" /> <property name="build.compiler" value="extJavac" /> </ant> </target> @@ -120,16 +119,6 @@ </executions> <dependencies> <dependency> - <groupId>velocity</groupId> - <artifactId>velocity</artifactId> - <version>${velocity-version}</version> - </dependency> - <dependency> - <groupId>velocity</groupId> - <artifactId>velocity-dep</artifactId> - <version>${velocity-version}</version> - </dependency> - <dependency> <groupId>org.python</groupId> <artifactId>jython-standalone</artifactId> <version>${jython-version}</version> diff --git a/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelException.java b/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelException.java index 55f0fe57b0..7ab422eb4f 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelException.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelException.java @@ -20,10 +20,7 @@ */ package org.apache.qpid; -import org.apache.qpid.framing.AMQFrame; -import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.ProtocolVersion; import org.apache.qpid.protocol.AMQConstant; /** @@ -34,24 +31,35 @@ public class AMQChannelException extends AMQException private final int _classId; private final int _methodId; /* AMQP version for which exception ocurred */ - private final byte major; - private final byte minor; + private final MethodRegistry _methodRegistry; - public AMQChannelException(AMQConstant errorCode, String msg, int classId, int methodId, byte major, byte minor, - Throwable cause) + + public AMQChannelException(AMQConstant errorCode, + String msg, + int classId, + int methodId, + MethodRegistry methodRegistry) { - super(errorCode, msg, cause); + super(errorCode, msg); _classId = classId; _methodId = methodId; - this.major = major; - this.minor = minor; + _methodRegistry = methodRegistry; + + } + + public int getClassId() + { + return _classId; + } + + public int getMethodId() + { + return _methodId; } - public AMQFrame getCloseFrame(int channel) + public MethodRegistry getMethodRegistry() { - MethodRegistry reg = MethodRegistry.getMethodRegistry(new ProtocolVersion(major,minor)); - return new AMQFrame(channel, reg.createChannelCloseBody(getErrorCode() == null ? AMQConstant.INTERNAL_ERROR.getCode() : getErrorCode().getCode(), - AMQShortString.validValueOf(getMessage()),_classId,_methodId)); + return _methodRegistry; } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionException.java b/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionException.java index 096c4ede80..ca70d19420 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionException.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionException.java @@ -22,9 +22,9 @@ package org.apache.qpid; import org.apache.qpid.framing.AMQFrame; +import org.apache.qpid.framing.AMQMethodBody; import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.MethodRegistry; -import org.apache.qpid.framing.ProtocolVersion; import org.apache.qpid.protocol.AMQConstant; /** @@ -35,32 +35,30 @@ public class AMQConnectionException extends AMQException private final int _classId; private final int _methodId; - /** AMQP version for which exception ocurred, major code. */ - private final byte major; + private final MethodRegistry _methodRegistry; - /** AMQP version for which exception ocurred, minor code. */ - private final byte minor; - - private boolean _closeConnetion; + public AMQConnectionException(AMQConstant errorCode, String msg, AMQMethodBody body, MethodRegistry methodRegistry) + { + this(errorCode, msg, body.getClazz(), body.getMethod(), methodRegistry, null); + } - public AMQConnectionException(AMQConstant errorCode, String msg, int classId, int methodId, byte major, byte minor, - Throwable cause) + public AMQConnectionException(AMQConstant errorCode, String msg, int classId, int methodId, MethodRegistry methodRegistry, + Throwable cause) { super(errorCode, msg, cause); _classId = classId; _methodId = methodId; - this.major = major; - this.minor = minor; + _methodRegistry = methodRegistry; + } - public AMQFrame getCloseFrame(int channel) + public AMQFrame getCloseFrame() { - MethodRegistry reg = MethodRegistry.getMethodRegistry(new ProtocolVersion(major,minor)); return new AMQFrame(0, - reg.createConnectionCloseBody(getErrorCode().getCode(), - AMQShortString.validValueOf(getMessage()), - _classId, - _methodId)); + _methodRegistry.createConnectionCloseBody(getErrorCode().getCode(), + AMQShortString.validValueOf(getMessage()), + _classId, + _methodId)); } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/AMQException.java b/qpid/java/common/src/main/java/org/apache/qpid/AMQException.java index 3741cb9902..7d2521a057 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/AMQException.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/AMQException.java @@ -20,7 +20,6 @@ */ package org.apache.qpid; -import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.protocol.AMQConstant; /** @@ -72,7 +71,6 @@ public class AMQException extends Exception this(null, (msg == null) ? "" : msg); } - @Deprecated public AMQException(AMQConstant errorCode, String msg) { this(errorCode, (msg == null) ? "" : msg, null); diff --git a/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java b/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java index 53e8c998c9..9d98168687 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java @@ -30,16 +30,8 @@ import java.util.ArrayList; import java.util.List; import java.util.ListIterator; -import org.apache.qpid.framing.AMQDataBlock; -import org.apache.qpid.framing.AMQDataBlockDecoder; -import org.apache.qpid.framing.AMQFrameDecodingException; -import org.apache.qpid.framing.AMQMethodBodyFactory; -import org.apache.qpid.framing.AMQProtocolVersionException; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.ByteArrayDataInput; -import org.apache.qpid.framing.EncodingUtils; -import org.apache.qpid.framing.ProtocolInitiation; -import org.apache.qpid.protocol.AMQVersionAwareProtocolSession; +import org.apache.qpid.framing.*; +import org.apache.qpid.protocol.AMQConstant; /** * AMQDecoder delegates the decoding of AMQP either to a data block decoder, or in the case of new connections, to a @@ -53,10 +45,9 @@ import org.apache.qpid.protocol.AMQVersionAwareProtocolSession; * TODO If protocol initiation decoder not needed, then don't create it. Probably not a big deal, but it adds to the * per-session overhead. */ -public class AMQDecoder +public abstract class AMQDecoder<T extends MethodProcessor> { - /** Holds the 'normal' AMQP data decoder. */ - private AMQDataBlockDecoder _dataBlockDecoder = new AMQDataBlockDecoder(); + private final T _methodProcessor; /** Holds the protocol initiation decoder. */ private ProtocolInitiation.Decoder _piDecoder = new ProtocolInitiation.Decoder(); @@ -64,26 +55,26 @@ public class AMQDecoder /** Flag to indicate whether this decoder needs to handle protocol initiation. */ private boolean _expectProtocolInitiation; - private AMQMethodBodyFactory _bodyFactory; private boolean _firstRead = true; + private int _maxFrameSize = AMQConstant.FRAME_MIN_SIZE.getCode(); + private List<ByteArrayInputStream> _remainingBufs = new ArrayList<ByteArrayInputStream>(); /** * Creates a new AMQP decoder. * * @param expectProtocolInitiation <tt>true</tt> if this decoder needs to handle protocol initiation. - * @param session protocol session (connection) + * @param methodProcessor method processor */ - public AMQDecoder(boolean expectProtocolInitiation, AMQVersionAwareProtocolSession session) + protected AMQDecoder(boolean expectProtocolInitiation, T methodProcessor) { _expectProtocolInitiation = expectProtocolInitiation; - _bodyFactory = new AMQMethodBodyFactory(session); + _methodProcessor = methodProcessor; } - /** * Sets the protocol initation flag, that determines whether decoding is handled by the data decoder of the protocol * initation decoder. This method is expected to be called with <tt>false</tt> once protocol initation completes. @@ -98,7 +89,12 @@ public class AMQDecoder public void setMaxFrameSize(final int frameMax) { - _dataBlockDecoder.setMaxFrameSize(frameMax); + _maxFrameSize = frameMax; + } + + public T getMethodProcessor() + { + return _methodProcessor; } private class RemainingByteArrayInputStream extends InputStream @@ -219,14 +215,13 @@ public class AMQDecoder } - public ArrayList<AMQDataBlock> decodeBuffer(ByteBuffer buf) throws AMQFrameDecodingException, AMQProtocolVersionException, IOException + public void decodeBuffer(ByteBuffer buf) throws AMQFrameDecodingException, AMQProtocolVersionException, IOException { - // get prior remaining data from accumulator - ArrayList<AMQDataBlock> dataBlocks = new ArrayList<AMQDataBlock>(); MarkableDataInput msg; + // get prior remaining data from accumulator ByteArrayInputStream bais; DataInput di; if(!_remainingBufs.isEmpty()) @@ -257,10 +252,10 @@ public class AMQDecoder { if(!_expectProtocolInitiation) { - enoughData = _dataBlockDecoder.decodable(msg); + enoughData = decodable(msg); if (enoughData) { - dataBlocks.add(_dataBlockDecoder.createAndPopulateFrame(_bodyFactory, msg)); + processInput(msg); } } else @@ -268,7 +263,7 @@ public class AMQDecoder enoughData = _piDecoder.decodable(msg); if (enoughData) { - dataBlocks.add(new ProtocolInitiation(msg)); + _methodProcessor.receiveProtocolHeader(new ProtocolInitiation(msg)); } } @@ -305,6 +300,106 @@ public class AMQDecoder } } } - return dataBlocks; } + + private boolean decodable(final MarkableDataInput in) throws AMQFrameDecodingException, IOException + { + final int remainingAfterAttributes = in.available() - (1 + 2 + 4 + 1); + // type, channel, body length and end byte + if (remainingAfterAttributes < 0) + { + return false; + } + + in.mark(8); + in.skip(1 + 2); + + + // Get an unsigned int, lifted from MINA ByteBuffer getUnsignedInt() + final long bodySize = in.readInt() & 0xffffffffL; + if (bodySize > _maxFrameSize) + { + throw new AMQFrameDecodingException(AMQConstant.FRAME_ERROR, + "Incoming frame size of " + + bodySize + + " is larger than negotiated maximum of " + + _maxFrameSize); + } + in.reset(); + + return (remainingAfterAttributes >= bodySize); + + } + + private void processInput(final MarkableDataInput in) + throws AMQFrameDecodingException, AMQProtocolVersionException, IOException + { + final byte type = in.readByte(); + + final int channel = in.readUnsignedShort(); + final long bodySize = EncodingUtils.readUnsignedInteger(in); + + // bodySize can be zero + if ((channel < 0) || (bodySize < 0)) + { + throw new AMQFrameDecodingException(AMQConstant.FRAME_ERROR, + "Undecodable frame: type = " + type + " channel = " + channel + + " bodySize = " + bodySize); + } + + processFrame(channel, type, bodySize, in); + + byte marker = in.readByte(); + if ((marker & 0xFF) != 0xCE) + { + throw new AMQFrameDecodingException(AMQConstant.FRAME_ERROR, + "End of frame marker not found. Read " + marker + " length=" + bodySize + + " type=" + type); + } + + } + + protected void processFrame(final int channel, final byte type, final long bodySize, final MarkableDataInput in) + throws AMQFrameDecodingException, IOException + { + switch (type) + { + case 1: + processMethod(channel, in); + break; + case 2: + ContentHeaderBody.process(in, _methodProcessor.getChannelMethodProcessor(channel), bodySize); + break; + case 3: + ContentBody.process(in, _methodProcessor.getChannelMethodProcessor(channel), bodySize); + break; + case 8: + HeartbeatBody.process(channel, in, _methodProcessor, bodySize); + break; + default: + throw new AMQFrameDecodingException(AMQConstant.FRAME_ERROR, "Unsupported frame type: " + type); + } + } + + + abstract void processMethod(int channelId, + MarkableDataInput in) + throws AMQFrameDecodingException, IOException; + + AMQFrameDecodingException newUnknownMethodException(final int classId, + final int methodId, + ProtocolVersion protocolVersion) + { + return new AMQFrameDecodingException(AMQConstant.COMMAND_INVALID, + "Method " + + methodId + + " unknown in AMQP version " + + protocolVersion + + " (while trying to decode class " + + classId + + " method " + + methodId + + "."); + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/codec/ClientDecoder.java b/qpid/java/common/src/main/java/org/apache/qpid/codec/ClientDecoder.java new file mode 100644 index 0000000000..5048193cac --- /dev/null +++ b/qpid/java/common/src/main/java/org/apache/qpid/codec/ClientDecoder.java @@ -0,0 +1,258 @@ +/* + * + * 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.codec; + +import java.io.IOException; + +import org.apache.qpid.framing.*; + +public class ClientDecoder extends AMQDecoder<ClientMethodProcessor<? extends ClientChannelMethodProcessor>> +{ + + /** + * Creates a new AMQP decoder. + * + * @param methodProcessor method processor + */ + public ClientDecoder(final ClientMethodProcessor<? extends ClientChannelMethodProcessor> methodProcessor) + { + super(false, methodProcessor); + } + + + void processMethod(int channelId, + MarkableDataInput in) + throws AMQFrameDecodingException, IOException + { + ClientMethodProcessor<? extends ClientChannelMethodProcessor> methodProcessor = getMethodProcessor(); + ClientChannelMethodProcessor channelMethodProcessor = methodProcessor.getChannelMethodProcessor(channelId); + final int classAndMethod = in.readInt(); + int classId = classAndMethod >> 16; + int methodId = classAndMethod & 0xFFFF; + methodProcessor.setCurrentMethod(classId, methodId); + try + { + switch (classAndMethod) + { + //CONNECTION_CLASS: + case 0x000a000a: + ConnectionStartBody.process(in, methodProcessor); + break; + case 0x000a0014: + ConnectionSecureBody.process(in, methodProcessor); + break; + case 0x000a001e: + ConnectionTuneBody.process(in, methodProcessor); + break; + case 0x000a0029: + ConnectionOpenOkBody.process(in, methodProcessor); + break; + case 0x000a002a: + ConnectionRedirectBody.process(in, methodProcessor); + break; + case 0x000a0032: + if (methodProcessor.getProtocolVersion().equals(ProtocolVersion.v8_0)) + { + ConnectionRedirectBody.process(in, methodProcessor); + } + else + { + ConnectionCloseBody.process(in, methodProcessor); + } + break; + case 0x000a0033: + if (methodProcessor.getProtocolVersion().equals(ProtocolVersion.v8_0)) + { + throw newUnknownMethodException(classId, methodId, + methodProcessor.getProtocolVersion()); + } + else + { + methodProcessor.receiveConnectionCloseOk(); + } + break; + case 0x000a003c: + if (methodProcessor.getProtocolVersion().equals(ProtocolVersion.v8_0)) + { + ConnectionCloseBody.process(in, methodProcessor); + } + else + { + throw newUnknownMethodException(classId, methodId, + methodProcessor.getProtocolVersion()); + } + break; + case 0x000a003d: + if (methodProcessor.getProtocolVersion().equals(ProtocolVersion.v8_0)) + { + methodProcessor.receiveConnectionCloseOk(); + } + else + { + throw newUnknownMethodException(classId, methodId, + methodProcessor.getProtocolVersion()); + } + break; + + // CHANNEL_CLASS: + + case 0x0014000b: + ChannelOpenOkBody.process(in, methodProcessor.getProtocolVersion(), channelMethodProcessor); + break; + case 0x00140014: + ChannelFlowBody.process(in, channelMethodProcessor); + break; + case 0x00140015: + ChannelFlowOkBody.process(in, channelMethodProcessor); + break; + case 0x0014001e: + ChannelAlertBody.process(in, channelMethodProcessor); + break; + case 0x00140028: + ChannelCloseBody.process(in, channelMethodProcessor); + break; + case 0x00140029: + channelMethodProcessor.receiveChannelCloseOk(); + break; + + // ACCESS_CLASS: + + case 0x001e000b: + AccessRequestOkBody.process(in, channelMethodProcessor); + break; + + // EXCHANGE_CLASS: + + case 0x0028000b: + if(!channelMethodProcessor.ignoreAllButCloseOk()) + { + channelMethodProcessor.receiveExchangeDeclareOk(); + } + break; + case 0x00280015: + if(!channelMethodProcessor.ignoreAllButCloseOk()) + { + channelMethodProcessor.receiveExchangeDeleteOk(); + } + break; + case 0x00280017: + ExchangeBoundOkBody.process(in, channelMethodProcessor); + break; + + + // QUEUE_CLASS: + + case 0x0032000b: + QueueDeclareOkBody.process(in, channelMethodProcessor); + break; + case 0x00320015: + if(!channelMethodProcessor.ignoreAllButCloseOk()) + { + channelMethodProcessor.receiveQueueBindOk(); + } + break; + case 0x0032001f: + QueuePurgeOkBody.process(in, channelMethodProcessor); + break; + case 0x00320029: + QueueDeleteOkBody.process(in, channelMethodProcessor); + break; + case 0x00320033: + if(!channelMethodProcessor.ignoreAllButCloseOk()) + { + channelMethodProcessor.receiveQueueUnbindOk(); + } + break; + + + // BASIC_CLASS: + + case 0x003c000b: + if(!channelMethodProcessor.ignoreAllButCloseOk()) + { + channelMethodProcessor.receiveBasicQosOk(); + } + break; + case 0x003c0015: + BasicConsumeOkBody.process(in, channelMethodProcessor); + break; + case 0x003c001f: + BasicCancelOkBody.process(in, channelMethodProcessor); + break; + case 0x003c0032: + BasicReturnBody.process(in, channelMethodProcessor); + break; + case 0x003c003c: + BasicDeliverBody.process(in, channelMethodProcessor); + break; + case 0x003c0047: + BasicGetOkBody.process(in, channelMethodProcessor); + break; + case 0x003c0048: + BasicGetEmptyBody.process(in, channelMethodProcessor); + break; + case 0x003c0065: + if(!channelMethodProcessor.ignoreAllButCloseOk()) + { + channelMethodProcessor.receiveBasicRecoverSyncOk(); + } + break; + case 0x003c006f: + if(!channelMethodProcessor.ignoreAllButCloseOk()) + { + channelMethodProcessor.receiveBasicRecoverSyncOk(); + } + break; + + // TX_CLASS: + + case 0x005a000b: + if(!channelMethodProcessor.ignoreAllButCloseOk()) + { + channelMethodProcessor.receiveTxSelectOk(); + } + break; + case 0x005a0015: + if(!channelMethodProcessor.ignoreAllButCloseOk()) + { + channelMethodProcessor.receiveTxCommitOk(); + } + break; + case 0x005a001f: + if(!channelMethodProcessor.ignoreAllButCloseOk()) + { + channelMethodProcessor.receiveTxRollbackOk(); + } + break; + + default: + throw newUnknownMethodException(classId, methodId, + methodProcessor.getProtocolVersion()); + + } + } + finally + { + methodProcessor.setCurrentMethod(0, 0); + } + } + +} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/codec/ServerDecoder.java b/qpid/java/common/src/main/java/org/apache/qpid/codec/ServerDecoder.java new file mode 100644 index 0000000000..3b138ba278 --- /dev/null +++ b/qpid/java/common/src/main/java/org/apache/qpid/codec/ServerDecoder.java @@ -0,0 +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.codec; + +import java.io.IOException; + +import org.apache.qpid.framing.*; + +public class ServerDecoder extends AMQDecoder<ServerMethodProcessor<? extends ServerChannelMethodProcessor>> +{ + + /** + * Creates a new AMQP decoder. + * + * @param methodProcessor method processor + */ + public ServerDecoder(final ServerMethodProcessor<? extends ServerChannelMethodProcessor> methodProcessor) + { + super(true, methodProcessor); + } + + void processMethod(int channelId, + MarkableDataInput in) + throws AMQFrameDecodingException, IOException + { + ServerMethodProcessor<? extends ServerChannelMethodProcessor> methodProcessor = getMethodProcessor(); + ServerChannelMethodProcessor channelMethodProcessor = methodProcessor.getChannelMethodProcessor(channelId); + final int classAndMethod = in.readInt(); + int classId = classAndMethod >> 16; + int methodId = classAndMethod & 0xFFFF; + methodProcessor.setCurrentMethod(classId, methodId); + try + { + switch (classAndMethod) + { + //CONNECTION_CLASS: + case 0x000a000b: + ConnectionStartOkBody.process(in, methodProcessor); + break; + case 0x000a0015: + ConnectionSecureOkBody.process(in, methodProcessor); + break; + case 0x000a001f: + ConnectionTuneOkBody.process(in, methodProcessor); + break; + case 0x000a0028: + ConnectionOpenBody.process(in, methodProcessor); + break; + case 0x000a0032: + if (methodProcessor.getProtocolVersion().equals(ProtocolVersion.v8_0)) + { + throw newUnknownMethodException(classId, methodId, + methodProcessor.getProtocolVersion()); + } + else + { + ConnectionCloseBody.process(in, methodProcessor); + } + break; + case 0x000a0033: + if (methodProcessor.getProtocolVersion().equals(ProtocolVersion.v8_0)) + { + throw newUnknownMethodException(classId, methodId, + methodProcessor.getProtocolVersion()); + } + else + { + methodProcessor.receiveConnectionCloseOk(); + } + break; + case 0x000a003c: + if (methodProcessor.getProtocolVersion().equals(ProtocolVersion.v8_0)) + { + ConnectionCloseBody.process(in, methodProcessor); + } + else + { + throw newUnknownMethodException(classId, methodId, + methodProcessor.getProtocolVersion()); + } + break; + case 0x000a003d: + if (methodProcessor.getProtocolVersion().equals(ProtocolVersion.v8_0)) + { + methodProcessor.receiveConnectionCloseOk(); + } + else + { + throw newUnknownMethodException(classId, methodId, + methodProcessor.getProtocolVersion()); + } + break; + + // CHANNEL_CLASS: + + case 0x0014000a: + ChannelOpenBody.process(channelId, in, methodProcessor); + break; + case 0x00140014: + ChannelFlowBody.process(in, channelMethodProcessor); + break; + case 0x00140015: + ChannelFlowOkBody.process(in, channelMethodProcessor); + break; + case 0x00140028: + ChannelCloseBody.process(in, channelMethodProcessor); + break; + case 0x00140029: + channelMethodProcessor.receiveChannelCloseOk(); + break; + + // ACCESS_CLASS: + + case 0x001e000a: + AccessRequestBody.process(in, channelMethodProcessor); + break; + + // EXCHANGE_CLASS: + + case 0x0028000a: + ExchangeDeclareBody.process(in, channelMethodProcessor); + break; + case 0x00280014: + ExchangeDeleteBody.process(in, channelMethodProcessor); + break; + case 0x00280016: + ExchangeBoundBody.process(in, channelMethodProcessor); + break; + + + // QUEUE_CLASS: + + case 0x0032000a: + QueueDeclareBody.process(in, channelMethodProcessor); + break; + case 0x00320014: + QueueBindBody.process(in, channelMethodProcessor); + break; + case 0x0032001e: + QueuePurgeBody.process(in, channelMethodProcessor); + break; + case 0x00320028: + QueueDeleteBody.process(in, channelMethodProcessor); + break; + case 0x00320032: + QueueUnbindBody.process(in, channelMethodProcessor); + break; + + + // BASIC_CLASS: + + case 0x003c000a: + BasicQosBody.process(in, channelMethodProcessor); + break; + case 0x003c0014: + BasicConsumeBody.process(in, channelMethodProcessor); + break; + case 0x003c001e: + BasicCancelBody.process(in, channelMethodProcessor); + break; + case 0x003c0028: + BasicPublishBody.process(in, channelMethodProcessor); + break; + case 0x003c0046: + BasicGetBody.process(in, channelMethodProcessor); + break; + case 0x003c0050: + BasicAckBody.process(in, channelMethodProcessor); + break; + case 0x003c005a: + BasicRejectBody.process(in, channelMethodProcessor); + break; + case 0x003c0064: + BasicRecoverBody.process(in, methodProcessor.getProtocolVersion(), channelMethodProcessor); + break; + case 0x003c0066: + BasicRecoverSyncBody.process(in, channelMethodProcessor); + break; + case 0x003c006e: + BasicRecoverSyncBody.process(in, channelMethodProcessor); + break; + + // TX_CLASS: + + case 0x005a000a: + if(!channelMethodProcessor.ignoreAllButCloseOk()) + { + channelMethodProcessor.receiveTxSelect(); + } + break; + case 0x005a0014: + if(!channelMethodProcessor.ignoreAllButCloseOk()) + { + channelMethodProcessor.receiveTxCommit(); + } + break; + case 0x005a001e: + if(!channelMethodProcessor.ignoreAllButCloseOk()) + { + channelMethodProcessor.receiveTxRollback(); + } + break; + + default: + throw newUnknownMethodException(classId, methodId, + methodProcessor.getProtocolVersion()); + + } + } + finally + { + methodProcessor.setCurrentMethod(0, 0); + } + } + +} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQDataBlockDecoder.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQDataBlockDecoder.java deleted file mode 100644 index 291b7e8d29..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQDataBlockDecoder.java +++ /dev/null @@ -1,120 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.framing; - -import java.io.IOException; - -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import org.apache.qpid.codec.MarkableDataInput; -import org.apache.qpid.protocol.AMQConstant; - -public class AMQDataBlockDecoder -{ - - private static final BodyFactory[] _bodiesSupported = new BodyFactory[Byte.MAX_VALUE]; - - static - { - _bodiesSupported[ContentHeaderBody.TYPE] = ContentHeaderBodyFactory.getInstance(); - _bodiesSupported[ContentBody.TYPE] = ContentBodyFactory.getInstance(); - _bodiesSupported[HeartbeatBody.TYPE] = new HeartbeatBodyFactory(); - } - - private Logger _logger = LoggerFactory.getLogger(AMQDataBlockDecoder.class); - private int _maxFrameSize = AMQConstant.FRAME_MIN_SIZE.getCode(); - - public AMQDataBlockDecoder() - { } - - public boolean decodable(MarkableDataInput in) throws AMQFrameDecodingException, IOException - { - final int remainingAfterAttributes = in.available() - (1 + 2 + 4 + 1); - // type, channel, body length and end byte - if (remainingAfterAttributes < 0) - { - return false; - } - - in.mark(8); - in.skip(1 + 2); - - - // Get an unsigned int, lifted from MINA ByteBuffer getUnsignedInt() - final long bodySize = in.readInt() & 0xffffffffL; - if(bodySize > _maxFrameSize) - { - throw new AMQFrameDecodingException(AMQConstant.FRAME_ERROR, "Incoming frame size of "+bodySize+" is larger than negotiated maximum of " + _maxFrameSize); - } - in.reset(); - - return (remainingAfterAttributes >= bodySize); - - } - - public AMQFrame createAndPopulateFrame(BodyFactory methodBodyFactory, MarkableDataInput in) - throws AMQFrameDecodingException, AMQProtocolVersionException, IOException - { - final byte type = in.readByte(); - - BodyFactory bodyFactory; - if (type == AMQMethodBody.TYPE) - { - bodyFactory = methodBodyFactory; - } - else - { - bodyFactory = _bodiesSupported[type]; - } - - if (bodyFactory == null) - { - throw new AMQFrameDecodingException(AMQConstant.FRAME_ERROR, "Unsupported frame type: " + type); - } - - final int channel = in.readUnsignedShort(); - final long bodySize = EncodingUtils.readUnsignedInteger(in); - - // bodySize can be zero - if ((channel < 0) || (bodySize < 0)) - { - throw new AMQFrameDecodingException(AMQConstant.FRAME_ERROR, "Undecodable frame: type = " + type + " channel = " + channel - + " bodySize = " + bodySize); - } - - AMQFrame frame = new AMQFrame(in, channel, bodySize, bodyFactory); - - byte marker = in.readByte(); - if ((marker & 0xFF) != 0xCE) - { - throw new AMQFrameDecodingException(AMQConstant.FRAME_ERROR, "End of frame marker not found. Read " + marker + " length=" + bodySize - + " type=" + type); - } - - return frame; - } - - public void setMaxFrameSize(final int maxFrameSize) - { - _maxFrameSize = maxFrameSize; - } -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQFrame.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQFrame.java index 238f28e73e..83397c37d8 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQFrame.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQFrame.java @@ -20,8 +20,6 @@ */ package org.apache.qpid.framing; -import org.apache.qpid.codec.MarkableDataInput; - import java.io.DataOutput; import java.io.IOException; @@ -39,12 +37,6 @@ public class AMQFrame extends AMQDataBlock implements EncodableAMQDataBlock _bodyFrame = bodyFrame; } - public AMQFrame(final MarkableDataInput in, final int channel, final long bodySize, final BodyFactory bodyFactory) throws AMQFrameDecodingException, IOException - { - this._channel = channel; - this._bodyFrame = bodyFactory.createBody(in,bodySize); - } - public long getSize() { return 1 + 2 + 4 + _bodyFrame.getSize() + 1; diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBody.java index 250b8e87d1..23315d4787 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBody.java @@ -20,28 +20,18 @@ */ package org.apache.qpid.framing; +import java.io.DataOutput; +import java.io.IOException; + import org.apache.qpid.AMQChannelException; import org.apache.qpid.AMQConnectionException; import org.apache.qpid.AMQException; import org.apache.qpid.protocol.AMQConstant; -import java.io.DataOutput; -import java.io.IOException; - public interface AMQMethodBody extends AMQBody { public static final byte TYPE = 1; - /** AMQP major version - * @return the major version*/ - public byte getMajor(); - - /** AMQP minor version - * @return the minor version*/ - public byte getMinor(); - - - /** @return unsigned short */ public int getClazz(); @@ -66,18 +56,18 @@ public interface AMQMethodBody extends AMQBody * * @param channelId The channel id that is not found * + * @param methodRegistry * @return new AMQChannelException */ - public AMQChannelException getChannelNotFoundException(int channelId); - - public AMQChannelException getChannelException(AMQConstant code, String message); - - public AMQChannelException getChannelException(AMQConstant code, String message, Throwable cause); - - public AMQConnectionException getConnectionException(AMQConstant code, String message); + public AMQChannelException getChannelNotFoundException(int channelId, final MethodRegistry methodRegistry); + public AMQChannelException getChannelException(AMQConstant code, + String message, + final MethodRegistry methodRegistry); - public AMQConnectionException getConnectionException(AMQConstant code, String message, Throwable cause); + public AMQConnectionException getConnectionException(AMQConstant code, + String message, + final MethodRegistry methodRegistry); public boolean execute(MethodDispatcher methodDispatcher, int channelId) throws AMQException; diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyFactory.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyFactory.java deleted file mode 100644 index 7fe293b6b7..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyFactory.java +++ /dev/null @@ -1,46 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.framing; - -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import org.apache.qpid.codec.MarkableDataInput; -import org.apache.qpid.protocol.AMQVersionAwareProtocolSession; - -import java.io.IOException; - -public class AMQMethodBodyFactory implements BodyFactory -{ - private static final Logger _log = LoggerFactory.getLogger(AMQMethodBodyFactory.class); - - private final AMQVersionAwareProtocolSession _protocolSession; - - public AMQMethodBodyFactory(AMQVersionAwareProtocolSession protocolSession) - { - _protocolSession = protocolSession; - } - - public AMQBody createBody(MarkableDataInput in, long bodySize) throws AMQFrameDecodingException, IOException - { - return _protocolSession.getMethodRegistry().convertToBody(in, bodySize); - } -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java index b1e8a73a0d..e40452edea 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java @@ -21,17 +21,16 @@ package org.apache.qpid.framing; +import java.io.DataInput; +import java.io.DataOutput; +import java.io.IOException; + import org.apache.qpid.AMQChannelException; import org.apache.qpid.AMQConnectionException; import org.apache.qpid.AMQException; -import org.apache.qpid.codec.MarkableDataInput; import org.apache.qpid.protocol.AMQConstant; import org.apache.qpid.protocol.AMQVersionAwareProtocolSession; -import java.io.DataInput; -import java.io.DataOutput; -import java.io.IOException; - public abstract class AMQMethodBodyImpl implements AMQMethodBody { public static final byte TYPE = 1; @@ -67,31 +66,26 @@ public abstract class AMQMethodBodyImpl implements AMQMethodBody * * @param channelId The channel id that is not found * + * @param methodRegistry * @return new AMQChannelException */ - public AMQChannelException getChannelNotFoundException(int channelId) - { - return getChannelException(AMQConstant.NOT_FOUND, "Channel not found for id:" + channelId); - } - - public AMQChannelException getChannelException(AMQConstant code, String message) + public AMQChannelException getChannelNotFoundException(int channelId, final MethodRegistry methodRegistry) { - return new AMQChannelException(code, message, getClazz(), getMethod(), getMajor(), getMinor(), null); + return getChannelException(AMQConstant.NOT_FOUND, "Channel not found for id:" + channelId, methodRegistry); } - public AMQChannelException getChannelException(AMQConstant code, String message, Throwable cause) + public AMQChannelException getChannelException(AMQConstant code, + String message, + final MethodRegistry methodRegistry) { - return new AMQChannelException(code, message, getClazz(), getMethod(), getMajor(), getMinor(), cause); + return new AMQChannelException(code, message, getClazz(), getMethod(), methodRegistry); } - public AMQConnectionException getConnectionException(AMQConstant code, String message) + public AMQConnectionException getConnectionException(AMQConstant code, + String message, + final MethodRegistry methodRegistry) { - return new AMQConnectionException(code, message, getClazz(), getMethod(), getMajor(), getMinor(), null); - } - - public AMQConnectionException getConnectionException(AMQConstant code, String message, Throwable cause) - { - return new AMQConnectionException(code, message, getClazz(), getMethod(), getMajor(), getMinor(), cause); + return new AMQConnectionException(code, message, this, methodRegistry); } public void handle(final int channelId, final AMQVersionAwareProtocolSession session) throws AMQException @@ -112,17 +106,6 @@ public abstract class AMQMethodBodyImpl implements AMQMethodBody } - protected byte readByte(DataInput buffer) throws IOException - { - return buffer.readByte(); - } - - protected AMQShortString readAMQShortString(MarkableDataInput buffer) throws IOException - { - AMQShortString str = buffer.readAMQShortString(); - return str == null ? null : str.intern(false); - } - protected int getSizeOf(AMQShortString string) { return EncodingUtils.encodedShortStringLength(string); @@ -148,11 +131,6 @@ public abstract class AMQMethodBodyImpl implements AMQMethodBody buffer.writeInt(i); } - protected FieldTable readFieldTable(DataInput buffer) throws AMQFrameDecodingException, IOException - { - return EncodingUtils.readFieldTable(buffer); - } - protected int getSizeOf(FieldTable table) { return EncodingUtils.encodedFieldTableLength(table); //To change body of created methods use File | Settings | File Templates. @@ -163,11 +141,6 @@ public abstract class AMQMethodBodyImpl implements AMQMethodBody EncodingUtils.writeFieldTableBytes(buffer, table); } - protected long readLong(DataInput buffer) throws IOException - { - return buffer.readLong(); - } - protected void writeLong(DataOutput buffer, long l) throws IOException { buffer.writeLong(l); @@ -183,11 +156,6 @@ public abstract class AMQMethodBodyImpl implements AMQMethodBody EncodingUtils.writeBytes(buffer,data); } - protected byte[] readBytes(DataInput buffer) throws IOException - { - return EncodingUtils.readBytes(buffer); - } - protected short readShort(DataInput buffer) throws IOException { return EncodingUtils.readShort(buffer); @@ -198,30 +166,6 @@ public abstract class AMQMethodBodyImpl implements AMQMethodBody EncodingUtils.writeShort(buffer, s); } - protected Content readContent(DataInput buffer) - { - return null; - } - - protected int getSizeOf(Content body) - { - return 0; - } - - protected void writeContent(DataOutput buffer, Content body) - { - } - - protected byte readBitfield(DataInput buffer) throws IOException - { - return readByte(buffer); - } - - protected int readUnsignedShort(DataInput buffer) throws IOException - { - return buffer.readUnsignedShort(); - } - protected void writeBitfield(DataOutput buffer, byte bitfield0) throws IOException { buffer.writeByte(bitfield0); @@ -232,21 +176,12 @@ public abstract class AMQMethodBodyImpl implements AMQMethodBody EncodingUtils.writeUnsignedShort(buffer, s); } - protected long readUnsignedInteger(DataInput buffer) throws IOException - { - return EncodingUtils.readUnsignedInteger(buffer); - } protected void writeUnsignedInteger(DataOutput buffer, long i) throws IOException { EncodingUtils.writeUnsignedInteger(buffer, i); } - protected short readUnsignedByte(DataInput buffer) throws IOException - { - return (short) buffer.readUnsignedByte(); - } - protected void writeUnsignedByte(DataOutput buffer, short unsignedByte) throws IOException { EncodingUtils.writeUnsignedByte(buffer, unsignedByte); diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyInstanceFactory.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyInstanceFactory.java deleted file mode 100644 index 88b1ca7189..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyInstanceFactory.java +++ /dev/null @@ -1,32 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -package org.apache.qpid.framing; - -import org.apache.qpid.codec.MarkableDataInput; - -import java.io.IOException; - - -public abstract interface AMQMethodBodyInstanceFactory -{ - public AMQMethodBody newInstance(MarkableDataInput buffer, long size) throws AMQFrameDecodingException, IOException; -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQShortString.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQShortString.java index 17735f5c9c..765d742789 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQShortString.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQShortString.java @@ -389,6 +389,17 @@ public final class AMQShortString implements CharSequence, Comparable<AMQShortSt { return new CharSubSequence(start + _sequenceOffset, end + _sequenceOffset); } + + @Override + public String toString() + { + char[] chars = new char[length()]; + for(int i = 0; i < length(); i++) + { + chars[i] = charAt(i); + } + return new String(chars); + } } public char[] asChars() diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/AccessRequestBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/AccessRequestBody.java index 38701385d6..8dec50c400 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/AccessRequestBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/AccessRequestBody.java @@ -22,25 +22,162 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface AccessRequestBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class AccessRequestBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public boolean getActive(); + public static final int CLASS_ID = 30; + public static final int METHOD_ID = 10; + + // Fields declared in specification + private final AMQShortString _realm; // [realm] + private final byte _bitfield0; // [exclusive, passive, active, write, read] + + // Constructor + public AccessRequestBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _realm = buffer.readAMQShortString(); + _bitfield0 = buffer.readByte(); + } + + public AccessRequestBody( + AMQShortString realm, + boolean exclusive, + boolean passive, + boolean active, + boolean write, + boolean read + ) + { + _realm = realm; + byte bitfield0 = (byte)0; + if( exclusive ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + + if( passive ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); + } + + if( active ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); + } + + if( write ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); + } + + if( read ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 4)); + } + _bitfield0 = bitfield0; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final AMQShortString getRealm() + { + return _realm; + } + public final boolean getExclusive() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + public final boolean getPassive() + { + return (((int)(_bitfield0)) & ( 1 << 1)) != 0; + } + public final boolean getActive() + { + return (((int)(_bitfield0)) & ( 1 << 2)) != 0; + } + public final boolean getWrite() + { + return (((int)(_bitfield0)) & ( 1 << 3)) != 0; + } + public final boolean getRead() + { + return (((int)(_bitfield0)) & ( 1 << 4)) != 0; + } - public boolean getExclusive(); + protected int getBodySize() + { + int size = 1; + size += getSizeOf( _realm ); + return size; + } - public boolean getPassive(); + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeAMQShortString( buffer, _realm ); + writeBitfield( buffer, _bitfield0 ); + } - public boolean getRead(); + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchAccessRequest(this, channelId); + } - public AMQShortString getRealm(); + public String toString() + { + StringBuilder buf = new StringBuilder("[AccessRequestBodyImpl: "); + buf.append( "realm=" ); + buf.append( getRealm() ); + buf.append( ", " ); + buf.append( "exclusive=" ); + buf.append( getExclusive() ); + buf.append( ", " ); + buf.append( "passive=" ); + buf.append( getPassive() ); + buf.append( ", " ); + buf.append( "active=" ); + buf.append( getActive() ); + buf.append( ", " ); + buf.append( "write=" ); + buf.append( getWrite() ); + buf.append( ", " ); + buf.append( "read=" ); + buf.append( getRead() ); + buf.append("]"); + return buf.toString(); + } - public boolean getWrite(); + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) throws IOException + { + AMQShortString realm = buffer.readAMQShortString(); + byte bitfield = buffer.readByte(); + boolean exclusive = (bitfield & 0x01) == 0x1 ; + boolean passive = (bitfield & 0x02) == 0x2 ; + boolean active = (bitfield & 0x04) == 0x4 ; + boolean write = (bitfield & 0x08) == 0x8 ; + boolean read = (bitfield & 0x10) == 0x10 ; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveAccessRequest(realm, exclusive, passive, active, write, read); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/AccessRequestOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/AccessRequestOkBody.java index aa7c171411..7ed0b3602b 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/AccessRequestOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/AccessRequestOkBody.java @@ -22,15 +22,87 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface AccessRequestOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class AccessRequestOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public int getTicket(); + public static final int CLASS_ID = 30; + public static final int METHOD_ID = 11; + + // Fields declared in specification + private final int _ticket; // [ticket] + + // Constructor + public AccessRequestOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _ticket = buffer.readUnsignedShort(); + } + + public AccessRequestOkBody( + int ticket + ) + { + _ticket = ticket; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getTicket() + { + return _ticket; + } + + protected int getBodySize() + { + int size = 2; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _ticket ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchAccessRequestOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[AccessRequestOkBodyImpl: "); + buf.append( "ticket=" ); + buf.append( getTicket() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput buffer, + final ClientChannelMethodProcessor dispatcher) + throws IOException + { + int ticket = buffer.readUnsignedShort(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveAccessRequestOk(ticket); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicAckBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicAckBody.java index 41c4af5ff0..68782231fe 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicAckBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicAckBody.java @@ -22,17 +22,105 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicAckBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicAckBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public long getDeliveryTag(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 80; + + // Fields declared in specification + private final long _deliveryTag; // [deliveryTag] + private final byte _bitfield0; // [multiple] + + // Constructor + public BasicAckBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _deliveryTag = buffer.readLong(); + _bitfield0 = buffer.readByte(); + } + + public BasicAckBody( + long deliveryTag, + boolean multiple + ) + { + _deliveryTag = deliveryTag; + byte bitfield0 = (byte)0; + if( multiple ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + _bitfield0 = bitfield0; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final long getDeliveryTag() + { + return _deliveryTag; + } + public final boolean getMultiple() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + + protected int getBodySize() + { + int size = 9; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeLong( buffer, _deliveryTag ); + writeBitfield( buffer, _bitfield0 ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicAck(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicAckBodyImpl: "); + buf.append( "deliveryTag=" ); + buf.append( getDeliveryTag() ); + buf.append( ", " ); + buf.append( "multiple=" ); + buf.append( getMultiple() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) throws IOException + { - public boolean getMultiple(); + long deliveryTag = buffer.readLong(); + boolean multiple = (buffer.readByte() & 0x01) != 0; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicAck(deliveryTag, multiple); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicCancelBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicCancelBody.java index 853b1583b9..c9a870e2a5 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicCancelBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicCancelBody.java @@ -22,17 +22,106 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicCancelBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicCancelBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public AMQShortString getConsumerTag(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 30; + + // Fields declared in specification + private final AMQShortString _consumerTag; // [consumerTag] + private final byte _bitfield0; // [nowait] + + // Constructor + public BasicCancelBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _consumerTag = buffer.readAMQShortString(); + _bitfield0 = buffer.readByte(); + } + + public BasicCancelBody( + AMQShortString consumerTag, + boolean nowait + ) + { + _consumerTag = consumerTag; + byte bitfield0 = (byte)0; + if( nowait ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + _bitfield0 = bitfield0; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final AMQShortString getConsumerTag() + { + return _consumerTag; + } + public final boolean getNowait() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + + protected int getBodySize() + { + int size = 1; + size += getSizeOf( _consumerTag ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeAMQShortString( buffer, _consumerTag ); + writeBitfield( buffer, _bitfield0 ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicCancel(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicCancelBodyImpl: "); + buf.append( "consumerTag=" ); + buf.append( getConsumerTag() ); + buf.append( ", " ); + buf.append( "nowait=" ); + buf.append( getNowait() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) throws IOException + { - public boolean getNowait(); + AMQShortString consumerTag = buffer.readAMQShortString(); + boolean noWait = (buffer.readByte() & 0x01) == 0x01; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicCancel(consumerTag, noWait); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicCancelOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicCancelOkBody.java index 623e89275a..8d16aa44ec 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicCancelOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicCancelOkBody.java @@ -22,15 +22,88 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicCancelOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicCancelOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public AMQShortString getConsumerTag(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 31; + + // Fields declared in specification + private final AMQShortString _consumerTag; // [consumerTag] + + // Constructor + public BasicCancelOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _consumerTag = buffer.readAMQShortString(); + } + + public BasicCancelOkBody( + AMQShortString consumerTag + ) + { + _consumerTag = consumerTag; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final AMQShortString getConsumerTag() + { + return _consumerTag; + } + + protected int getBodySize() + { + int size = 0; + size += getSizeOf( _consumerTag ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeAMQShortString( buffer, _consumerTag ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicCancelOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicCancelOkBodyImpl: "); + buf.append( "consumerTag=" ); + buf.append( getConsumerTag() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput in, + final ClientChannelMethodProcessor dispatcher) + throws IOException + { + AMQShortString consumerTag = in.readAMQShortString(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicCancelOk(consumerTag); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicConsumeBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicConsumeBody.java index d263899082..502fa07e78 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicConsumeBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicConsumeBody.java @@ -22,29 +22,193 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicConsumeBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicConsumeBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public FieldTable getArguments(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 20; + + // Fields declared in specification + private final int _ticket; // [ticket] + private final AMQShortString _queue; // [queue] + private final AMQShortString _consumerTag; // [consumerTag] + private final byte _bitfield0; // [noLocal, noAck, exclusive, nowait] + private final FieldTable _arguments; // [arguments] + + // Constructor + public BasicConsumeBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _ticket = buffer.readUnsignedShort(); + _queue = buffer.readAMQShortString(); + _consumerTag = buffer.readAMQShortString(); + _bitfield0 = buffer.readByte(); + _arguments = EncodingUtils.readFieldTable(buffer); + } + + public BasicConsumeBody( + int ticket, + AMQShortString queue, + AMQShortString consumerTag, + boolean noLocal, + boolean noAck, + boolean exclusive, + boolean nowait, + FieldTable arguments + ) + { + _ticket = ticket; + _queue = queue; + _consumerTag = consumerTag; + byte bitfield0 = (byte)0; + if( noLocal ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + + if( noAck ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); + } + + if( exclusive ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); + } + + if( nowait ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); + } + + _bitfield0 = bitfield0; + _arguments = arguments; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getTicket() + { + return _ticket; + } + public final AMQShortString getQueue() + { + return _queue; + } + public final AMQShortString getConsumerTag() + { + return _consumerTag; + } + public final boolean getNoLocal() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + public final boolean getNoAck() + { + return (((int)(_bitfield0)) & ( 1 << 1)) != 0; + } + public final boolean getExclusive() + { + return (((int)(_bitfield0)) & ( 1 << 2)) != 0; + } + public final boolean getNowait() + { + return (((int)(_bitfield0)) & ( 1 << 3)) != 0; + } + public final FieldTable getArguments() + { + return _arguments; + } - public AMQShortString getConsumerTag(); + protected int getBodySize() + { + int size = 3; + size += getSizeOf( _queue ); + size += getSizeOf( _consumerTag ); + size += getSizeOf( _arguments ); + return size; + } - public boolean getExclusive(); + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _ticket ); + writeAMQShortString( buffer, _queue ); + writeAMQShortString( buffer, _consumerTag ); + writeBitfield( buffer, _bitfield0 ); + writeFieldTable( buffer, _arguments ); + } - public boolean getNoAck(); + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicConsume(this, channelId); + } - public boolean getNoLocal(); + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicConsumeBodyImpl: "); + buf.append( "ticket=" ); + buf.append( getTicket() ); + buf.append( ", " ); + buf.append( "queue=" ); + buf.append( getQueue() ); + buf.append( ", " ); + buf.append( "consumerTag=" ); + buf.append( getConsumerTag() ); + buf.append( ", " ); + buf.append( "noLocal=" ); + buf.append( getNoLocal() ); + buf.append( ", " ); + buf.append( "noAck=" ); + buf.append( getNoAck() ); + buf.append( ", " ); + buf.append( "exclusive=" ); + buf.append( getExclusive() ); + buf.append( ", " ); + buf.append( "nowait=" ); + buf.append( getNowait() ); + buf.append( ", " ); + buf.append( "arguments=" ); + buf.append( getArguments() ); + buf.append("]"); + return buf.toString(); + } - public boolean getNowait(); + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) + throws IOException, AMQFrameDecodingException + { - public AMQShortString getQueue(); + int ticket = buffer.readUnsignedShort(); + AMQShortString queue = buffer.readAMQShortString(); + AMQShortString consumerTag = buffer.readAMQShortString(); + byte bitfield = buffer.readByte(); - public int getTicket(); + boolean noLocal = (bitfield & 0x01) == 0x01; + boolean noAck = (bitfield & 0x02) == 0x02; + boolean exclusive = (bitfield & 0x04) == 0x04; + boolean nowait = (bitfield & 0x08) == 0x08; + FieldTable arguments = EncodingUtils.readFieldTable(buffer); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicConsume(queue, consumerTag, noLocal, noAck, exclusive, nowait, arguments); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicConsumeOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicConsumeOkBody.java index a73cb9605d..d3df7f222a 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicConsumeOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicConsumeOkBody.java @@ -22,15 +22,88 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicConsumeOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicConsumeOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public AMQShortString getConsumerTag(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 21; + + // Fields declared in specification + private final AMQShortString _consumerTag; // [consumerTag] + + // Constructor + public BasicConsumeOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _consumerTag = buffer.readAMQShortString(); + } + + public BasicConsumeOkBody( + AMQShortString consumerTag + ) + { + _consumerTag = consumerTag; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final AMQShortString getConsumerTag() + { + return _consumerTag; + } + + protected int getBodySize() + { + int size = 0; + size += getSizeOf( _consumerTag ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeAMQShortString( buffer, _consumerTag ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicConsumeOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicConsumeOkBodyImpl: "); + buf.append( "consumerTag=" ); + buf.append( getConsumerTag() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput buffer, + final ClientChannelMethodProcessor dispatcher) + throws IOException + { + AMQShortString consumerTag = buffer.readAMQShortString(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicConsumeOk(consumerTag); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicDeliverBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicDeliverBody.java index 07781c0026..f61ee2d55b 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicDeliverBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicDeliverBody.java @@ -22,23 +22,148 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicDeliverBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicDeliverBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public AMQShortString getConsumerTag(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 60; + + // Fields declared in specification + private final AMQShortString _consumerTag; // [consumerTag] + private final long _deliveryTag; // [deliveryTag] + private final byte _bitfield0; // [redelivered] + private final AMQShortString _exchange; // [exchange] + private final AMQShortString _routingKey; // [routingKey] + + // Constructor + public BasicDeliverBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _consumerTag = buffer.readAMQShortString(); + _deliveryTag = buffer.readLong(); + _bitfield0 = buffer.readByte(); + _exchange = buffer.readAMQShortString(); + _routingKey = buffer.readAMQShortString(); + } + + public BasicDeliverBody( + AMQShortString consumerTag, + long deliveryTag, + boolean redelivered, + AMQShortString exchange, + AMQShortString routingKey + ) + { + _consumerTag = consumerTag; + _deliveryTag = deliveryTag; + byte bitfield0 = (byte)0; + if( redelivered ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + + _bitfield0 = bitfield0; + _exchange = exchange; + _routingKey = routingKey; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final AMQShortString getConsumerTag() + { + return _consumerTag; + } + public final long getDeliveryTag() + { + return _deliveryTag; + } + public final boolean getRedelivered() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + public final AMQShortString getExchange() + { + return _exchange; + } + public final AMQShortString getRoutingKey() + { + return _routingKey; + } + + protected int getBodySize() + { + int size = 9; + size += getSizeOf( _consumerTag ); + size += getSizeOf( _exchange ); + size += getSizeOf( _routingKey ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeAMQShortString( buffer, _consumerTag ); + writeLong( buffer, _deliveryTag ); + writeBitfield( buffer, _bitfield0 ); + writeAMQShortString( buffer, _exchange ); + writeAMQShortString( buffer, _routingKey ); + } - public long getDeliveryTag(); + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicDeliver(this, channelId); + } - public AMQShortString getExchange(); + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicDeliverBodyImpl: "); + buf.append( "consumerTag=" ); + buf.append( getConsumerTag() ); + buf.append( ", " ); + buf.append( "deliveryTag=" ); + buf.append( getDeliveryTag() ); + buf.append( ", " ); + buf.append( "redelivered=" ); + buf.append( getRedelivered() ); + buf.append( ", " ); + buf.append( "exchange=" ); + buf.append( getExchange() ); + buf.append( ", " ); + buf.append( "routingKey=" ); + buf.append( getRoutingKey() ); + buf.append("]"); + return buf.toString(); + } - public boolean getRedelivered(); + public static void process(final MarkableDataInput buffer, + final ClientChannelMethodProcessor dispatcher) throws IOException + { - public AMQShortString getRoutingKey(); + AMQShortString consumerTag = buffer.readAMQShortString(); + long deliveryTag = buffer.readLong(); + boolean redelivered = (buffer.readByte() & 0x01) != 0; + AMQShortString exchange = buffer.readAMQShortString(); + AMQShortString routingKey = buffer.readAMQShortString(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicDeliver(consumerTag, deliveryTag, redelivered, exchange, routingKey); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicGetBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicGetBody.java index b2a27cf840..68a6f2980b 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicGetBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicGetBody.java @@ -22,19 +22,120 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicGetBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicGetBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public boolean getNoAck(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 70; + + // Fields declared in specification + private final int _ticket; // [ticket] + private final AMQShortString _queue; // [queue] + private final byte _bitfield0; // [noAck] + + // Constructor + public BasicGetBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _ticket = buffer.readUnsignedShort(); + _queue = buffer.readAMQShortString(); + _bitfield0 = buffer.readByte(); + } + + public BasicGetBody( + int ticket, + AMQShortString queue, + boolean noAck + ) + { + _ticket = ticket; + _queue = queue; + byte bitfield0 = (byte)0; + if( noAck ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + _bitfield0 = bitfield0; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getTicket() + { + return _ticket; + } + public final AMQShortString getQueue() + { + return _queue; + } + public final boolean getNoAck() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + + protected int getBodySize() + { + int size = 3; + size += getSizeOf( _queue ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _ticket ); + writeAMQShortString( buffer, _queue ); + writeBitfield( buffer, _bitfield0 ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicGet(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicGetBodyImpl: "); + buf.append( "ticket=" ); + buf.append( getTicket() ); + buf.append( ", " ); + buf.append( "queue=" ); + buf.append( getQueue() ); + buf.append( ", " ); + buf.append( "noAck=" ); + buf.append( getNoAck() ); + buf.append("]"); + return buf.toString(); + } - public AMQShortString getQueue(); + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) + throws IOException + { - public int getTicket(); + int ticket = buffer.readUnsignedShort(); + AMQShortString queue = buffer.readAMQShortString(); + boolean noAck = (buffer.readByte() & 0x01) != 0; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicGet(queue, noAck); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicGetEmptyBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicGetEmptyBody.java index 758d15ba37..f37fb632db 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicGetEmptyBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicGetEmptyBody.java @@ -22,15 +22,87 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicGetEmptyBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicGetEmptyBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public AMQShortString getClusterId(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 72; + + // Fields declared in specification + private final AMQShortString _clusterId; // [clusterId] + + // Constructor + public BasicGetEmptyBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _clusterId = buffer.readAMQShortString(); + } + + public BasicGetEmptyBody( + AMQShortString clusterId + ) + { + _clusterId = clusterId; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final AMQShortString getClusterId() + { + return _clusterId; + } + + protected int getBodySize() + { + int size = 0; + size += getSizeOf( _clusterId ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeAMQShortString( buffer, _clusterId ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicGetEmpty(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicGetEmptyBody: "); + buf.append( "clusterId=" ); + buf.append( getClusterId() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput buffer, + final ClientChannelMethodProcessor dispatcher) throws IOException + { + AMQShortString clusterId = buffer.readAMQShortString(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicGetEmpty(); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicGetOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicGetOkBody.java index fac54d975c..37e9bdae5a 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicGetOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicGetOkBody.java @@ -22,23 +22,146 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicGetOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicGetOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public long getDeliveryTag(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 71; + + // Fields declared in specification + private final long _deliveryTag; // [deliveryTag] + private final byte _bitfield0; // [redelivered] + private final AMQShortString _exchange; // [exchange] + private final AMQShortString _routingKey; // [routingKey] + private final long _messageCount; // [messageCount] + + // Constructor + public BasicGetOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _deliveryTag = buffer.readLong(); + _bitfield0 = buffer.readByte(); + _exchange = buffer.readAMQShortString(); + _routingKey = buffer.readAMQShortString(); + _messageCount = EncodingUtils.readUnsignedInteger(buffer); + } + + public BasicGetOkBody( + long deliveryTag, + boolean redelivered, + AMQShortString exchange, + AMQShortString routingKey, + long messageCount + ) + { + _deliveryTag = deliveryTag; + byte bitfield0 = (byte)0; + if( redelivered ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + + _bitfield0 = bitfield0; + _exchange = exchange; + _routingKey = routingKey; + _messageCount = messageCount; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final long getDeliveryTag() + { + return _deliveryTag; + } + public final boolean getRedelivered() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + public final AMQShortString getExchange() + { + return _exchange; + } + public final AMQShortString getRoutingKey() + { + return _routingKey; + } + public final long getMessageCount() + { + return _messageCount; + } + + protected int getBodySize() + { + int size = 13; + size += getSizeOf( _exchange ); + size += getSizeOf( _routingKey ); + return size; + } - public AMQShortString getExchange(); + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeLong( buffer, _deliveryTag ); + writeBitfield( buffer, _bitfield0 ); + writeAMQShortString( buffer, _exchange ); + writeAMQShortString( buffer, _routingKey ); + writeUnsignedInteger( buffer, _messageCount ); + } - public long getMessageCount(); + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicGetOk(this, channelId); + } - public boolean getRedelivered(); + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicGetOkBodyImpl: "); + buf.append( "deliveryTag=" ); + buf.append( getDeliveryTag() ); + buf.append( ", " ); + buf.append( "redelivered=" ); + buf.append( getRedelivered() ); + buf.append( ", " ); + buf.append( "exchange=" ); + buf.append( getExchange() ); + buf.append( ", " ); + buf.append( "routingKey=" ); + buf.append( getRoutingKey() ); + buf.append( ", " ); + buf.append( "messageCount=" ); + buf.append( getMessageCount() ); + buf.append("]"); + return buf.toString(); + } - public AMQShortString getRoutingKey(); + public static void process(final MarkableDataInput buffer, + final ClientChannelMethodProcessor dispatcher) throws IOException + { + long deliveryTag = buffer.readLong(); + boolean redelivered = (buffer.readByte() & 0x01) != 0; + AMQShortString exchange = buffer.readAMQShortString(); + AMQShortString routingKey = buffer.readAMQShortString(); + long messageCount = EncodingUtils.readUnsignedInteger(buffer); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicGetOk(deliveryTag, redelivered, exchange, routingKey, messageCount); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicPublishBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicPublishBody.java index f71e012cd8..8e5d71a804 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicPublishBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicPublishBody.java @@ -22,23 +22,149 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicPublishBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicPublishBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public AMQShortString getExchange(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 40; + + // Fields declared in specification + private final int _ticket; // [ticket] + private final AMQShortString _exchange; // [exchange] + private final AMQShortString _routingKey; // [routingKey] + private final byte _bitfield0; // [mandatory, immediate] + + // Constructor + public BasicPublishBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _ticket = buffer.readUnsignedShort(); + _exchange = buffer.readAMQShortString(); + _routingKey = buffer.readAMQShortString(); + _bitfield0 = buffer.readByte(); + } + + public BasicPublishBody( + int ticket, + AMQShortString exchange, + AMQShortString routingKey, + boolean mandatory, + boolean immediate + ) + { + _ticket = ticket; + _exchange = exchange; + _routingKey = routingKey; + byte bitfield0 = (byte)0; + if( mandatory ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + + if( immediate ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); + } + _bitfield0 = bitfield0; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getTicket() + { + return _ticket; + } + public final AMQShortString getExchange() + { + return _exchange; + } + public final AMQShortString getRoutingKey() + { + return _routingKey; + } + public final boolean getMandatory() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + public final boolean getImmediate() + { + return (((int)(_bitfield0)) & ( 1 << 1)) != 0; + } + + protected int getBodySize() + { + int size = 3; + size += getSizeOf( _exchange ); + size += getSizeOf( _routingKey ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _ticket ); + writeAMQShortString( buffer, _exchange ); + writeAMQShortString( buffer, _routingKey ); + writeBitfield( buffer, _bitfield0 ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicPublish(this, channelId); + } - public boolean getImmediate(); + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicPublishBodyImpl: "); + buf.append( "ticket=" ); + buf.append( getTicket() ); + buf.append( ", " ); + buf.append( "exchange=" ); + buf.append( getExchange() ); + buf.append( ", " ); + buf.append( "routingKey=" ); + buf.append( getRoutingKey() ); + buf.append( ", " ); + buf.append( "mandatory=" ); + buf.append( getMandatory() ); + buf.append( ", " ); + buf.append( "immediate=" ); + buf.append( getImmediate() ); + buf.append("]"); + return buf.toString(); + } - public boolean getMandatory(); + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) throws IOException + { - public AMQShortString getRoutingKey(); + int ticket = buffer.readUnsignedShort(); + AMQShortString exchange = buffer.readAMQShortString(); + AMQShortString routingKey = buffer.readAMQShortString(); + byte bitfield = buffer.readByte(); - public int getTicket(); + boolean mandatory = (bitfield & 0x01) != 0; + boolean immediate = (bitfield & 0x02) != 0; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicPublish(exchange, routingKey, mandatory, immediate); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicQosBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicQosBody.java index 909a5dae8b..6b7e90f41f 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicQosBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicQosBody.java @@ -22,19 +22,118 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicQosBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicQosBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public boolean getGlobal(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 10; + + // Fields declared in specification + private final long _prefetchSize; // [prefetchSize] + private final int _prefetchCount; // [prefetchCount] + private final byte _bitfield0; // [global] + + // Constructor + public BasicQosBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _prefetchSize = EncodingUtils.readUnsignedInteger(buffer); + _prefetchCount = buffer.readUnsignedShort(); + _bitfield0 = buffer.readByte(); + } + + public BasicQosBody( + long prefetchSize, + int prefetchCount, + boolean global + ) + { + _prefetchSize = prefetchSize; + _prefetchCount = prefetchCount; + byte bitfield0 = (byte)0; + if( global ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + _bitfield0 = bitfield0; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final long getPrefetchSize() + { + return _prefetchSize; + } + public final int getPrefetchCount() + { + return _prefetchCount; + } + public final boolean getGlobal() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + + protected int getBodySize() + { + int size = 7; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedInteger( buffer, _prefetchSize ); + writeUnsignedShort( buffer, _prefetchCount ); + writeBitfield( buffer, _bitfield0 ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicQos(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicQosBodyImpl: "); + buf.append( "prefetchSize=" ); + buf.append( getPrefetchSize() ); + buf.append( ", " ); + buf.append( "prefetchCount=" ); + buf.append( getPrefetchCount() ); + buf.append( ", " ); + buf.append( "global=" ); + buf.append( getGlobal() ); + buf.append("]"); + return buf.toString(); + } - public int getPrefetchCount(); + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) throws IOException + { - public long getPrefetchSize(); + long prefetchSize = EncodingUtils.readUnsignedInteger(buffer); + int prefetchCount = buffer.readUnsignedShort(); + boolean global = (buffer.readByte() & 0x01) == 0x01; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicQos(prefetchSize, prefetchCount, global); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicQosOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicQosOkBody.java index b37cd30e73..4be10906c2 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicQosOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicQosOkBody.java @@ -22,13 +22,66 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicQosOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicQosOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 11; + + // Fields declared in specification + + // Constructor + public BasicQosOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + } + + public BasicQosOkBody( + ) + { + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + + protected int getBodySize() + { + int size = 0; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicQosOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicQosOkBodyImpl: "); + buf.append("]"); + return buf.toString(); + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverBody.java index 57e5637222..e5490c4827 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverBody.java @@ -22,15 +22,94 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicRecoverBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicRecoverBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public boolean getRequeue(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 100; + + // Fields declared in specification + private final byte _bitfield0; // [requeue] + + // Constructor + public BasicRecoverBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _bitfield0 = buffer.readByte(); + } + + public BasicRecoverBody( + boolean requeue + ) + { + byte bitfield0 = (byte)0; + if( requeue ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + _bitfield0 = bitfield0; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final boolean getRequeue() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + + protected int getBodySize() + { + int size = 1; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeBitfield( buffer, _bitfield0 ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicRecover(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicRecoverBodyImpl: "); + buf.append( "requeue=" ); + buf.append( getRequeue() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput in, + final ProtocolVersion protocolVersion, + final ServerChannelMethodProcessor dispatcher) throws IOException + { + boolean requeue = (in.readByte() & 0x01) == 0x01; + boolean sync = (ProtocolVersion.v8_0.equals(protocolVersion)); + + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicRecover(requeue, sync); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverOkBody.java deleted file mode 100644 index a4abdd0cd7..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverOkBody.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface BasicRecoverOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverSyncBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverSyncBody.java index 9175da5796..f82ee78862 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverSyncBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverSyncBody.java @@ -22,15 +22,94 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 0-91 + */ package org.apache.qpid.framing; -public interface BasicRecoverSyncBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicRecoverSyncBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + private int _methodId; + + public static final int CLASS_ID = 60; + + // Fields declared in specification + private final byte _bitfield0; // [requeue] + + // Constructor + public BasicRecoverSyncBody(MarkableDataInput buffer, ProtocolVersion protocolVersion) throws AMQFrameDecodingException, IOException + { + _methodId = ProtocolVersion.v0_9.equals(protocolVersion) ? 102 : 110; + _bitfield0 = buffer.readByte(); + } + + public BasicRecoverSyncBody(ProtocolVersion protocolVersion, + boolean requeue + ) + { + _methodId = ProtocolVersion.v0_9.equals(protocolVersion) ? 102 : 110; + + byte bitfield0 = (byte)0; + if( requeue ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + _bitfield0 = bitfield0; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return _methodId; + } + + public final boolean getRequeue() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + + protected int getBodySize() + { + int size = 1; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeBitfield( buffer, _bitfield0 ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicRecoverSync(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicRecoverSyncBodyImpl: "); + buf.append( "requeue=" ); + buf.append( getRequeue() ); + buf.append("]"); + return buf.toString(); + } - public boolean getRequeue(); + public static void process(final MarkableDataInput in, + final ServerChannelMethodProcessor dispatcher) throws IOException + { + boolean requeue = (in.readByte() & 0x01) == 0x01; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicRecover(requeue, true); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverSyncOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverSyncOkBody.java index c34aeda625..dc60d53952 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverSyncOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRecoverSyncOkBody.java @@ -22,13 +22,66 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 0-91 + */ package org.apache.qpid.framing; -public interface BasicRecoverSyncOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; + +public class BasicRecoverSyncOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + + public static final int CLASS_ID = 60; + public final int _ownMethodId; + + // Fields declared in specification + + // Constructor + public BasicRecoverSyncOkBody(ProtocolVersion protocolVersion) + { + if(ProtocolVersion.v0_91.equals(protocolVersion)) + { + _ownMethodId = 111; + } + else + { + _ownMethodId = 101; + } + } + + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return _ownMethodId; + } + + + protected int getBodySize() + { + return 0; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicRecoverSyncOk(this, channelId); + } + + public String toString() + { + return "[BasicRecoverSyncOkBody]"; + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRejectBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRejectBody.java index 87cd1083fb..8c8757f1d2 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRejectBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicRejectBody.java @@ -22,17 +22,105 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicRejectBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicRejectBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public long getDeliveryTag(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 90; + + // Fields declared in specification + private final long _deliveryTag; // [deliveryTag] + private final byte _bitfield0; // [requeue] + + // Constructor + public BasicRejectBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _deliveryTag = buffer.readLong(); + _bitfield0 = buffer.readByte(); + } + + public BasicRejectBody( + long deliveryTag, + boolean requeue + ) + { + _deliveryTag = deliveryTag; + byte bitfield0 = (byte)0; + if( requeue ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + _bitfield0 = bitfield0; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final long getDeliveryTag() + { + return _deliveryTag; + } + public final boolean getRequeue() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + + protected int getBodySize() + { + int size = 9; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeLong( buffer, _deliveryTag ); + writeBitfield( buffer, _bitfield0 ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicReject(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicRejectBodyImpl: "); + buf.append( "deliveryTag=" ); + buf.append( getDeliveryTag() ); + buf.append( ", " ); + buf.append( "requeue=" ); + buf.append( getRequeue() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) throws IOException + { - public boolean getRequeue(); + long deliveryTag = buffer.readLong(); + boolean requeue = (buffer.readByte() & 0x01) != 0; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicReject(deliveryTag, requeue); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicReturnBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicReturnBody.java index ace37b61fa..afdb343c9f 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicReturnBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/BasicReturnBody.java @@ -22,21 +22,129 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface BasicReturnBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class BasicReturnBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public AMQShortString getExchange(); + public static final int CLASS_ID = 60; + public static final int METHOD_ID = 50; + + // Fields declared in specification + private final int _replyCode; // [replyCode] + private final AMQShortString _replyText; // [replyText] + private final AMQShortString _exchange; // [exchange] + private final AMQShortString _routingKey; // [routingKey] + + // Constructor + public BasicReturnBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _replyCode = buffer.readUnsignedShort(); + _replyText = buffer.readAMQShortString(); + _exchange = buffer.readAMQShortString(); + _routingKey = buffer.readAMQShortString(); + } + + public BasicReturnBody( + int replyCode, + AMQShortString replyText, + AMQShortString exchange, + AMQShortString routingKey + ) + { + _replyCode = replyCode; + _replyText = replyText; + _exchange = exchange; + _routingKey = routingKey; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getReplyCode() + { + return _replyCode; + } + public final AMQShortString getReplyText() + { + return _replyText; + } + public final AMQShortString getExchange() + { + return _exchange; + } + public final AMQShortString getRoutingKey() + { + return _routingKey; + } + + protected int getBodySize() + { + int size = 2; + size += getSizeOf( _replyText ); + size += getSizeOf( _exchange ); + size += getSizeOf( _routingKey ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _replyCode ); + writeAMQShortString( buffer, _replyText ); + writeAMQShortString( buffer, _exchange ); + writeAMQShortString( buffer, _routingKey ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchBasicReturn(this, channelId); + } - public int getReplyCode(); + public String toString() + { + StringBuilder buf = new StringBuilder("[BasicReturnBodyImpl: "); + buf.append( "replyCode=" ); + buf.append( getReplyCode() ); + buf.append( ", " ); + buf.append( "replyText=" ); + buf.append( getReplyText() ); + buf.append( ", " ); + buf.append( "exchange=" ); + buf.append( getExchange() ); + buf.append( ", " ); + buf.append( "routingKey=" ); + buf.append( getRoutingKey() ); + buf.append("]"); + return buf.toString(); + } - public AMQShortString getReplyText(); + public static void process(final MarkableDataInput buffer, + final ClientChannelMethodProcessor dispatcher) throws IOException + { - public AMQShortString getRoutingKey(); + int replyCode = buffer.readUnsignedShort(); + AMQShortString replyText = buffer.readAMQShortString(); + AMQShortString exchange = buffer.readAMQShortString(); + AMQShortString routingKey = buffer.readAMQShortString(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveBasicReturn(replyCode, replyText, exchange, routingKey); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/BodyFactory.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/BodyFactory.java deleted file mode 100644 index 554e9373d8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/BodyFactory.java +++ /dev/null @@ -1,33 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.framing; - -import org.apache.qpid.codec.MarkableDataInput; - -import java.io.IOException; - -/** - * Any class that is capable of turning a stream of bytes into an AMQ structure must implement this interface. - */ -public interface BodyFactory -{ - AMQBody createBody(MarkableDataInput in, long bodySize) throws AMQFrameDecodingException, IOException; -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelAlertBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelAlertBody.java index 5c2354551a..289cf2cc10 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelAlertBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelAlertBody.java @@ -22,19 +22,116 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ChannelAlertBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ChannelAlertBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public FieldTable getDetails(); + public static final int CLASS_ID = 20; + public static final int METHOD_ID = 30; + + // Fields declared in specification + private final int _replyCode; // [replyCode] + private final AMQShortString _replyText; // [replyText] + private final FieldTable _details; // [details] + + // Constructor + public ChannelAlertBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _replyCode = buffer.readUnsignedShort(); + _replyText = buffer.readAMQShortString(); + _details = EncodingUtils.readFieldTable(buffer); + } + + public ChannelAlertBody( + int replyCode, + AMQShortString replyText, + FieldTable details + ) + { + _replyCode = replyCode; + _replyText = replyText; + _details = details; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getReplyCode() + { + return _replyCode; + } + public final AMQShortString getReplyText() + { + return _replyText; + } + public final FieldTable getDetails() + { + return _details; + } + + protected int getBodySize() + { + int size = 2; + size += getSizeOf( _replyText ); + size += getSizeOf( _details ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _replyCode ); + writeAMQShortString( buffer, _replyText ); + writeFieldTable( buffer, _details ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchChannelAlert(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[ChannelAlertBodyImpl: "); + buf.append( "replyCode=" ); + buf.append( getReplyCode() ); + buf.append( ", " ); + buf.append( "replyText=" ); + buf.append( getReplyText() ); + buf.append( ", " ); + buf.append( "details=" ); + buf.append( getDetails() ); + buf.append("]"); + return buf.toString(); + } - public int getReplyCode(); + public static void process(final MarkableDataInput buffer, + final ClientChannelMethodProcessor dispatcher) + throws IOException, AMQFrameDecodingException + { - public AMQShortString getReplyText(); + int replyCode = buffer.readUnsignedShort(); + AMQShortString replyText = buffer.readAMQShortString(); + FieldTable details = EncodingUtils.readFieldTable(buffer); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveChannelAlert(replyCode, replyText, details); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelCloseBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelCloseBody.java index d791b9125e..a3b92a1fad 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelCloseBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelCloseBody.java @@ -22,21 +22,127 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ChannelCloseBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ChannelCloseBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public int getClassId(); + public static final int CLASS_ID = 20; + public static final int METHOD_ID = 40; + + // Fields declared in specification + private final int _replyCode; // [replyCode] + private final AMQShortString _replyText; // [replyText] + private final int _classId; // [classId] + private final int _methodId; // [methodId] + + // Constructor + public ChannelCloseBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _replyCode = buffer.readUnsignedShort(); + _replyText = buffer.readAMQShortString(); + _classId = buffer.readUnsignedShort(); + _methodId = buffer.readUnsignedShort(); + } + + public ChannelCloseBody( + int replyCode, + AMQShortString replyText, + int classId, + int methodId + ) + { + _replyCode = replyCode; + _replyText = replyText; + _classId = classId; + _methodId = methodId; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getReplyCode() + { + return _replyCode; + } + public final AMQShortString getReplyText() + { + return _replyText; + } + public final int getClassId() + { + return _classId; + } + public final int getMethodId() + { + return _methodId; + } + + protected int getBodySize() + { + int size = 6; + size += getSizeOf( _replyText ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _replyCode ); + writeAMQShortString( buffer, _replyText ); + writeUnsignedShort( buffer, _classId ); + writeUnsignedShort( buffer, _methodId ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchChannelClose(this, channelId); + } - public int getMethodId(); + public String toString() + { + StringBuilder buf = new StringBuilder("[ChannelCloseBodyImpl: "); + buf.append( "replyCode=" ); + buf.append( getReplyCode() ); + buf.append( ", " ); + buf.append( "replyText=" ); + buf.append( getReplyText() ); + buf.append( ", " ); + buf.append( "classId=" ); + buf.append( getClassId() ); + buf.append( ", " ); + buf.append( "methodId=" ); + buf.append( getMethodId() ); + buf.append("]"); + return buf.toString(); + } - public int getReplyCode(); + public static void process(final MarkableDataInput buffer, + final ChannelMethodProcessor dispatcher) throws IOException + { - public AMQShortString getReplyText(); + int replyCode = buffer.readUnsignedShort(); + AMQShortString replyText = buffer.readAMQShortString(); + int classId = buffer.readUnsignedShort(); + int methodId = buffer.readUnsignedShort(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveChannelClose(replyCode, replyText, classId, methodId); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelCloseOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelCloseOkBody.java index 4d9b8b4c3a..e9b1572eef 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelCloseOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelCloseOkBody.java @@ -22,13 +22,64 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ChannelCloseOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ChannelCloseOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + public static final ChannelCloseOkBody INSTANCE = new ChannelCloseOkBody(); + + public static final int CLASS_ID = 20; + public static final int METHOD_ID = 41; + + // Fields declared in specification + + // Constructor + public ChannelCloseOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + } + + private ChannelCloseOkBody() + { + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + + protected int getBodySize() + { + return 0; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchChannelCloseOk(this, channelId); + } + + public String toString() + { + return "[ChannelCloseOkBody]"; + + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelFlowBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelFlowBody.java index 08a75df9a5..1c3cc47d4e 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelFlowBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelFlowBody.java @@ -22,15 +22,83 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ChannelFlowBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ChannelFlowBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public boolean getActive(); + public static final int CLASS_ID = 20; + public static final int METHOD_ID = 20; + + // Fields declared in specification + private final boolean _active; // [active] + + // Constructor + public ChannelFlowBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _active = (buffer.readByte() & 0x01) == 0x01; + } + + public ChannelFlowBody(boolean active) + { + _active = active; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final boolean getActive() + { + return _active; + } + + protected int getBodySize() + { + return 1; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeBitfield( buffer, _active ? (byte)1 : (byte)0); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchChannelFlow(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[ChannelFlowBodyImpl: "); + buf.append( "active=" ); + buf.append( getActive() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput buffer, + final ChannelMethodProcessor dispatcher) throws IOException + { + boolean active = (buffer.readByte() & 0x01) == 0x01; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveChannelFlow(active); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelFlowOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelFlowOkBody.java index 750156ea9c..9d4a2b09a1 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelFlowOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelFlowOkBody.java @@ -22,15 +22,85 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ChannelFlowOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ChannelFlowOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public boolean getActive(); + public static final int CLASS_ID = 20; + public static final int METHOD_ID = 21; + + // Fields declared in specification + private final boolean _active; // [active] + + // Constructor + public ChannelFlowOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _active = (buffer.readByte() & 0x01) == 0x01; + } + + public ChannelFlowOkBody(boolean active) + { + _active = active; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final boolean getActive() + { + return _active; + } + + protected int getBodySize() + { + int size = 1; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeBitfield( buffer, _active ? (byte)1 : (byte)0 ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchChannelFlowOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[ChannelFlowOkBodyImpl: "); + buf.append( "active=" ); + buf.append( getActive() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput buffer, + final ChannelMethodProcessor dispatcher) + throws IOException + { + boolean active = (buffer.readByte() & 0x01) == 0x01; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveChannelFlowOk(active); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamConsumeBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelMethodProcessor.java index 0226547fd8..84cd1e13c2 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamConsumeBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelMethodProcessor.java @@ -18,30 +18,21 @@ * under the License. * */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - package org.apache.qpid.framing; -public interface StreamConsumeBody extends EncodableAMQDataBlock, AMQMethodBody +public interface ChannelMethodProcessor { + void receiveChannelFlow(boolean active); - public AMQShortString getConsumerTag(); - - public boolean getExclusive(); + void receiveChannelFlowOk(boolean active); + void receiveChannelClose(int replyCode, AMQShortString replyText, int classId, int methodId); - public boolean getNoLocal(); + void receiveChannelCloseOk(); - public boolean getNowait(); + void receiveMessageContent(byte[] data); - public AMQShortString getQueue(); + void receiveMessageHeader(BasicContentHeaderProperties properties, long bodySize); - public int getTicket(); + boolean ignoreAllButCloseOk(); } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelOkBody.java deleted file mode 100644 index 4f332aea8f..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelOkBody.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface ChannelOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelOpenBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelOpenBody.java index 0333cdae9f..af583f5fda 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelOpenBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelOpenBody.java @@ -22,15 +22,74 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ChannelOpenBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ChannelOpenBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public AMQShortString getOutOfBand(); + public static final int CLASS_ID = 20; + public static final int METHOD_ID = 10; + + + // Constructor + public ChannelOpenBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + // ignore unused OOB string + buffer.readAMQShortString(); + } + + public ChannelOpenBody() + { + + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + protected int getBodySize() + { + return 1; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeAMQShortString( buffer, null ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchChannelOpen(this, channelId); + } + + public String toString() + { + return "[ChannelOpenBody] "; + } + + public static void process(final int channelId, + final MarkableDataInput buffer, + final ServerMethodProcessor dispatcher) throws IOException + { + buffer.readAMQShortString(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveChannelOpen(channelId); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelOpenOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelOpenOkBody.java index 7682cea782..e3b4f38a8c 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelOpenOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelOpenOkBody.java @@ -22,14 +22,92 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ChannelOpenOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ChannelOpenOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + public static final int CLASS_ID = 20; + public static final int METHOD_ID = 11; + + public static final ChannelOpenOkBody INSTANCE_0_8 = new ChannelOpenOkBody(true); + public static final ChannelOpenOkBody INSTANCE_0_9 = new ChannelOpenOkBody(false); + + public static ChannelOpenOkBody getInstance(ProtocolVersion protocolVersion, MarkableDataInput input) + throws IOException + { + final boolean isAMQP08 = ProtocolVersion.v8_0.equals(protocolVersion); + ChannelOpenOkBody instance = isAMQP08 ? INSTANCE_0_8 : INSTANCE_0_9; + if(!isAMQP08) + { + EncodingUtils.readBytes(input); + } + return instance; + } + // Fields declared in specification + private final boolean _isAMQP08; + // Constructor + + private ChannelOpenOkBody(boolean isAMQP08) + { + _isAMQP08 = isAMQP08; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + + protected int getBodySize() + { + return _isAMQP08 ? 0 : 4; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + if(!_isAMQP08) + { + buffer.writeInt(0); + } + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchChannelOpenOk(this, channelId); + } + + public String toString() + { + return "[ChannelOpenOkBody]"; + } + + public static void process(final MarkableDataInput in, + final ProtocolVersion protocolVersion, + final ClientChannelMethodProcessor dispatcher) throws IOException + { + if(!ProtocolVersion.v8_0.equals(protocolVersion)) + { + EncodingUtils.readBytes(in); + } + + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveChannelOpenOk(); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelPingBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelPingBody.java deleted file mode 100644 index 29f2013e79..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelPingBody.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface ChannelPingBody extends EncodableAMQDataBlock, AMQMethodBody -{ -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelPongBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelPongBody.java deleted file mode 100644 index 2ac2388246..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelPongBody.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface ChannelPongBody extends EncodableAMQDataBlock, AMQMethodBody -{ -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelResumeBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelResumeBody.java deleted file mode 100644 index f3b77e1db9..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ChannelResumeBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface ChannelResumeBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public byte[] getChannelId(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ClientChannelMethodProcessor.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ClientChannelMethodProcessor.java new file mode 100644 index 0000000000..bef143e39b --- /dev/null +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ClientChannelMethodProcessor.java @@ -0,0 +1,78 @@ +/* + * + * 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.framing; + +public interface ClientChannelMethodProcessor extends ChannelMethodProcessor +{ + void receiveChannelOpenOk(); + + void receiveChannelAlert(int replyCode, final AMQShortString replyText, FieldTable details); + + void receiveAccessRequestOk(int ticket); + + void receiveExchangeDeclareOk(); + + void receiveExchangeDeleteOk(); + + void receiveExchangeBoundOk(int replyCode, AMQShortString replyText); + + void receiveQueueBindOk(); + + void receiveQueueUnbindOk(); + + void receiveQueueDeclareOk(final AMQShortString queue, long messageCount, long consumerCount); + + void receiveQueuePurgeOk(long messageCount); + + void receiveQueueDeleteOk(long messageCount); + + void receiveBasicRecoverSyncOk(); + + void receiveBasicQosOk(); + + void receiveBasicConsumeOk(AMQShortString consumerTag); + + void receiveBasicCancelOk(AMQShortString consumerTag); + + void receiveBasicReturn(int replyCode, + AMQShortString replyText, + AMQShortString exchange, + AMQShortString routingKey); + + void receiveBasicDeliver(AMQShortString consumerTag, + long deliveryTag, + boolean redelivered, + AMQShortString exchange, AMQShortString routingKey); + + void receiveBasicGetOk(long deliveryTag, + boolean redelivered, + AMQShortString exchange, + AMQShortString routingKey, long messageCount); + + void receiveBasicGetEmpty(); + + void receiveTxSelectOk(); + + void receiveTxCommitOk(); + + void receiveTxRollbackOk(); + +} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ClientMethodDispatcher.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ClientMethodDispatcher.java index 0b31d99463..97de0ac487 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ClientMethodDispatcher.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ClientMethodDispatcher.java @@ -63,4 +63,13 @@ public interface ClientMethodDispatcher public boolean dispatchTxRollbackOk(TxRollbackOkBody body, int channelId) throws AMQException; public boolean dispatchTxSelectOk(TxSelectOkBody body, int channelId) throws AMQException; -}
\ No newline at end of file + boolean dispatchConnectionRedirect(ConnectionRedirectBody connectionRedirectBody, int channelId) throws AMQException; + boolean dispatchAccessRequestOk(AccessRequestOkBody accessRequestOkBody, int channelId) throws AMQException; + + boolean dispatchQueueUnbindOk(QueueUnbindOkBody queueUnbindOkBody, int channelId) throws AMQException; + + boolean dispatchBasicRecoverSyncOk(BasicRecoverSyncOkBody basicRecoverSyncOkBody, int channelId) + throws AMQException; + + boolean dispatchChannelAlert(ChannelAlertBody channelAlertBody, int channelId) throws AMQException; +} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FilePublishBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ClientMethodProcessor.java index 5377882c27..0b599ee40a 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FilePublishBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ClientMethodProcessor.java @@ -18,29 +18,22 @@ * under the License. * */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - package org.apache.qpid.framing; -public interface FilePublishBody extends EncodableAMQDataBlock, AMQMethodBody +public interface ClientMethodProcessor<T extends ClientChannelMethodProcessor> extends MethodProcessor<T> { + void receiveConnectionStart(short versionMajor, + short versionMinor, + FieldTable serverProperties, + byte[] mechanisms, + byte[] locales); - public AMQShortString getExchange(); - - public AMQShortString getIdentifier(); + void receiveConnectionSecure(byte[] challenge); - public boolean getImmediate(); + void receiveConnectionRedirect(AMQShortString host, AMQShortString knownHosts); - public boolean getMandatory(); + void receiveConnectionTune(int channelMax, long frameMax, int heartbeat); - public AMQShortString getRoutingKey(); + void receiveConnectionOpenOk(AMQShortString knownHosts); - public int getTicket(); } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionCloseBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionCloseBody.java index d03892d29f..546cf5fa0a 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionCloseBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionCloseBody.java @@ -22,21 +22,124 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 0-91 + */ package org.apache.qpid.framing; -public interface ConnectionCloseBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ConnectionCloseBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public int getClassId(); + public static final int CLASS_ID = 10; + + private final int _ownMethodId; + // Fields declared in specification + private final int _replyCode; // [replyCode] + private final AMQShortString _replyText; // [replyText] + private final int _classId; // [classId] + private final int _methodId; // [methodId] + + // Constructor + public ConnectionCloseBody(MarkableDataInput buffer, ProtocolVersion protocolVersion) throws AMQFrameDecodingException, IOException + { + _ownMethodId = ProtocolVersion.v8_0.equals(protocolVersion) ? 60 : 50; + _replyCode = buffer.readUnsignedShort(); + _replyText = buffer.readAMQShortString(); + _classId = buffer.readUnsignedShort(); + _methodId = buffer.readUnsignedShort(); + } + + public ConnectionCloseBody(ProtocolVersion protocolVersion, + int replyCode, + AMQShortString replyText, + int classId, + int methodId + ) + { + _ownMethodId = ProtocolVersion.v8_0.equals(protocolVersion) ? 60 : 50; + _replyCode = replyCode; + _replyText = replyText; + _classId = classId; + _methodId = methodId; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return _ownMethodId; + } + + public final int getReplyCode() + { + return _replyCode; + } + public final AMQShortString getReplyText() + { + return _replyText; + } + public final int getClassId() + { + return _classId; + } + public final int getMethodId() + { + return _methodId; + } + + protected int getBodySize() + { + int size = 6; + size += getSizeOf( _replyText ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _replyCode ); + writeAMQShortString( buffer, _replyText ); + writeUnsignedShort( buffer, _classId ); + writeUnsignedShort( buffer, _methodId ); + } - public int getMethodId(); + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchConnectionClose(this, channelId); + } - public int getReplyCode(); + public String toString() + { + StringBuilder buf = new StringBuilder("[ConnectionCloseBodyImpl: "); + buf.append( "replyCode=" ); + buf.append( getReplyCode() ); + buf.append( ", " ); + buf.append( "replyText=" ); + buf.append( getReplyText() ); + buf.append( ", " ); + buf.append( "classId=" ); + buf.append( getClassId() ); + buf.append( ", " ); + buf.append( "methodId=" ); + buf.append( getMethodId() ); + buf.append("]"); + return buf.toString(); + } - public AMQShortString getReplyText(); + public static void process(final MarkableDataInput buffer, final MethodProcessor dispatcher) throws IOException + { + int replyCode = buffer.readUnsignedShort(); + AMQShortString replyText = buffer.readAMQShortString(); + int classId = buffer.readUnsignedShort(); + int methodId = buffer.readUnsignedShort(); + dispatcher.receiveConnectionClose(replyCode, replyText, classId, methodId); + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionCloseOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionCloseOkBody.java index f849095877..30e9f90b9a 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionCloseOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionCloseOkBody.java @@ -22,13 +22,61 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 0-91 + */ package org.apache.qpid.framing; -public interface ConnectionCloseOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ConnectionCloseOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + private final int _ownMethodId; + + public static final int CLASS_ID = 10; + + public static final ConnectionCloseOkBody CONNECTION_CLOSE_OK_0_8 = new ConnectionCloseOkBody(61); + public static final ConnectionCloseOkBody CONNECTION_CLOSE_OK_0_9 = new ConnectionCloseOkBody(51); + + // Constructor + private ConnectionCloseOkBody(int methodId) + { + _ownMethodId = methodId; + } + + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return _ownMethodId; + } + + + protected int getBodySize() + { + return 0; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchConnectionCloseOk(this, channelId); + } + + public String toString() + { + return "[ConnectionCloseOkBody]"; + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionOpenBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionOpenBody.java index cfa52b5f44..7fb815ae40 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionOpenBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionOpenBody.java @@ -22,19 +22,114 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ConnectionOpenBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ConnectionOpenBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public AMQShortString getCapabilities(); + public static final int CLASS_ID = 10; + public static final int METHOD_ID = 40; + + // Fields declared in specification + private final AMQShortString _virtualHost; // [virtualHost] + private final AMQShortString _capabilities; // [capabilities] + private final boolean _insist; // [insist] + + // Constructor + public ConnectionOpenBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _virtualHost = buffer.readAMQShortString(); + _capabilities = buffer.readAMQShortString(); + _insist = (buffer.readByte() & 0x01) == 0x01; + } + + public ConnectionOpenBody( + AMQShortString virtualHost, + AMQShortString capabilities, + boolean insist + ) + { + _virtualHost = virtualHost; + _capabilities = capabilities; + _insist = insist; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final AMQShortString getVirtualHost() + { + return _virtualHost; + } + public final AMQShortString getCapabilities() + { + return _capabilities; + } + public final boolean getInsist() + { + return _insist; + } + + protected int getBodySize() + { + int size = 1; + size += getSizeOf( _virtualHost ); + size += getSizeOf( _capabilities ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeAMQShortString( buffer, _virtualHost ); + writeAMQShortString( buffer, _capabilities ); + writeBitfield( buffer, _insist ? (byte)1 : (byte)0); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchConnectionOpen(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[ConnectionOpenBodyImpl: "); + buf.append( "virtualHost=" ); + buf.append( getVirtualHost() ); + buf.append( ", " ); + buf.append( "capabilities=" ); + buf.append( getCapabilities() ); + buf.append( ", " ); + buf.append( "insist=" ); + buf.append( getInsist() ); + buf.append("]"); + return buf.toString(); + } - public boolean getInsist(); + public static void process(final MarkableDataInput buffer, final ServerMethodProcessor dispatcher) throws IOException + { - public AMQShortString getVirtualHost(); + AMQShortString virtualHost = buffer.readAMQShortString(); + AMQShortString capabilities = buffer.readAMQShortString(); + boolean insist = (buffer.readByte() & 0x01) == 0x01; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveConnectionOpen(virtualHost, capabilities, insist); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionOpenOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionOpenOkBody.java index eb2122fd74..95c48873f3 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionOpenOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionOpenOkBody.java @@ -22,15 +22,87 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ConnectionOpenOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ConnectionOpenOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public AMQShortString getKnownHosts(); + public static final int CLASS_ID = 10; + public static final int METHOD_ID = 41; + + // Fields declared in specification + private final AMQShortString _knownHosts; // [knownHosts] + + // Constructor + public ConnectionOpenOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _knownHosts = buffer.readAMQShortString(); + } + + public ConnectionOpenOkBody( + AMQShortString knownHosts + ) + { + _knownHosts = knownHosts; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final AMQShortString getKnownHosts() + { + return _knownHosts; + } + + protected int getBodySize() + { + int size = 0; + size += getSizeOf( _knownHosts ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeAMQShortString( buffer, _knownHosts ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchConnectionOpenOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[ConnectionOpenOkBodyImpl: "); + buf.append( "knownHosts=" ); + buf.append( getKnownHosts() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput buffer, final ClientMethodProcessor dispatcher) throws IOException + { + AMQShortString knownHosts = buffer.readAMQShortString(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveConnectionOpenOk(knownHosts); + } + + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionRedirectBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionRedirectBody.java index df200e8572..491cc25125 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionRedirectBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionRedirectBody.java @@ -22,17 +22,99 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ConnectionRedirectBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ConnectionRedirectBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + private final int _ownMethodId; + + public static final int CLASS_ID = 10; + + // Fields declared in specification + private final AMQShortString _host; // [host] + private final AMQShortString _knownHosts; // [knownHosts] + + // Constructor + public ConnectionRedirectBody(MarkableDataInput buffer, ProtocolVersion protocolVersion) throws AMQFrameDecodingException, IOException + { + _ownMethodId = ProtocolVersion.v8_0.equals(protocolVersion) ? 50 : 42; + _host = buffer.readAMQShortString(); + _knownHosts = buffer.readAMQShortString(); + } + + public ConnectionRedirectBody(ProtocolVersion protocolVersion, AMQShortString host, AMQShortString knownHosts) + { + _ownMethodId = ProtocolVersion.v8_0.equals(protocolVersion) ? 50 : 42; + _host = host; + _knownHosts = knownHosts; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return _ownMethodId; + } + + public final AMQShortString getHost() + { + return _host; + } + public final AMQShortString getKnownHosts() + { + return _knownHosts; + } + + protected int getBodySize() + { + int size = 0; + size += getSizeOf( _host ); + size += getSizeOf( _knownHosts ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeAMQShortString( buffer, _host ); + writeAMQShortString( buffer, _knownHosts ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchConnectionRedirect(this, channelId); + } - public AMQShortString getHost(); + public String toString() + { + StringBuilder buf = new StringBuilder("[ConnectionRedirectBodyImpl: "); + buf.append( "host=" ); + buf.append( getHost() ); + buf.append( ", " ); + buf.append( "knownHosts=" ); + buf.append( getKnownHosts() ); + buf.append("]"); + return buf.toString(); + } - public AMQShortString getKnownHosts(); + public static void process(final MarkableDataInput buffer, final ClientMethodProcessor dispatcher) throws IOException + { + AMQShortString host = buffer.readAMQShortString(); + AMQShortString knownHosts = buffer.readAMQShortString(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveConnectionRedirect(host, knownHosts); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionSecureBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionSecureBody.java index ebcdc2cf4d..e10af3b4c1 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionSecureBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionSecureBody.java @@ -22,15 +22,88 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ConnectionSecureBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ConnectionSecureBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public byte[] getChallenge(); + public static final int CLASS_ID = 10; + public static final int METHOD_ID = 20; + + // Fields declared in specification + private final byte[] _challenge; // [challenge] + + // Constructor + public ConnectionSecureBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _challenge = EncodingUtils.readBytes(buffer); + } + + public ConnectionSecureBody( + byte[] challenge + ) + { + _challenge = challenge; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final byte[] getChallenge() + { + return _challenge; + } + + protected int getBodySize() + { + int size = 0; + size += getSizeOf( _challenge ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeBytes( buffer, _challenge ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchConnectionSecure(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[ConnectionSecureBodyImpl: "); + buf.append( "challenge=" ); + buf.append( getChallenge() == null ? "null" : java.util.Arrays.toString( getChallenge() ) ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput in, final ClientMethodProcessor dispatcher) + throws IOException, AMQFrameDecodingException + + { + byte[] challenge = EncodingUtils.readBytes(in); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveConnectionSecure(challenge); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionSecureOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionSecureOkBody.java index 7abbe9d18c..4c4a249bb6 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionSecureOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionSecureOkBody.java @@ -22,15 +22,86 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ConnectionSecureOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ConnectionSecureOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public byte[] getResponse(); + public static final int CLASS_ID = 10; + public static final int METHOD_ID = 21; + + // Fields declared in specification + private final byte[] _response; // [response] + + // Constructor + public ConnectionSecureOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _response = EncodingUtils.readBytes(buffer); + } + + public ConnectionSecureOkBody( + byte[] response + ) + { + _response = response; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final byte[] getResponse() + { + return _response; + } + + protected int getBodySize() + { + int size = 0; + size += getSizeOf( _response ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeBytes( buffer, _response ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchConnectionSecureOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[ConnectionSecureOkBodyImpl: "); + buf.append( "response=" ); + buf.append( getResponse() == null ? "null" : java.util.Arrays.toString( getResponse() ) ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput in, final ServerMethodProcessor dispatcher) throws IOException + { + byte[] response = EncodingUtils.readBytes(in); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveConnectionSecureOk(response); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionStartBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionStartBody.java index 3219a9f392..3b94919d4e 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionStartBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionStartBody.java @@ -22,23 +22,132 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ConnectionStartBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ConnectionStartBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public byte[] getLocales(); + public static final int CLASS_ID = 10; + public static final int METHOD_ID = 10; + + // Fields declared in specification + private final short _versionMajor; // [versionMajor] + private final short _versionMinor; // [versionMinor] + private final FieldTable _serverProperties; // [serverProperties] + private final byte[] _mechanisms; // [mechanisms] + private final byte[] _locales; // [locales] + + public ConnectionStartBody( + short versionMajor, + short versionMinor, + FieldTable serverProperties, + byte[] mechanisms, + byte[] locales + ) + { + _versionMajor = versionMajor; + _versionMinor = versionMinor; + _serverProperties = serverProperties; + _mechanisms = mechanisms; + _locales = locales; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final short getVersionMajor() + { + return _versionMajor; + } + public final short getVersionMinor() + { + return _versionMinor; + } + public final FieldTable getServerProperties() + { + return _serverProperties; + } + public final byte[] getMechanisms() + { + return _mechanisms; + } + public final byte[] getLocales() + { + return _locales; + } + + protected int getBodySize() + { + int size = 2; + size += getSizeOf( _serverProperties ); + size += getSizeOf( _mechanisms ); + size += getSizeOf( _locales ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedByte( buffer, _versionMajor ); + writeUnsignedByte( buffer, _versionMinor ); + writeFieldTable( buffer, _serverProperties ); + writeBytes( buffer, _mechanisms ); + writeBytes( buffer, _locales ); + } - public byte[] getMechanisms(); + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchConnectionStart(this, channelId); + } - public FieldTable getServerProperties(); + public String toString() + { + StringBuilder buf = new StringBuilder("[ConnectionStartBodyImpl: "); + buf.append( "versionMajor=" ); + buf.append( getVersionMajor() ); + buf.append( ", " ); + buf.append( "versionMinor=" ); + buf.append( getVersionMinor() ); + buf.append( ", " ); + buf.append( "serverProperties=" ); + buf.append( getServerProperties() ); + buf.append( ", " ); + buf.append( "mechanisms=" ); + buf.append( getMechanisms() == null ? "null" : java.util.Arrays.toString( getMechanisms() ) ); + buf.append( ", " ); + buf.append( "locales=" ); + buf.append( getLocales() == null ? "null" : java.util.Arrays.toString( getLocales() ) ); + buf.append("]"); + return buf.toString(); + } - public short getVersionMajor(); + public static void process(final MarkableDataInput in, final ClientMethodProcessor dispatcher) + throws IOException, AMQFrameDecodingException + { + short versionMajor = (short) in.readUnsignedByte(); + short versionMinor = (short) in.readUnsignedByte(); + FieldTable serverProperties = EncodingUtils.readFieldTable(in); + byte[] mechanisms = EncodingUtils.readBytes(in); + byte[] locales = EncodingUtils.readBytes(in); - public short getVersionMinor(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveConnectionStart(versionMajor, versionMinor, serverProperties, mechanisms, locales); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionStartOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionStartOkBody.java index bd45ce0fa0..5b6a8e3ef7 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionStartOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionStartOkBody.java @@ -22,21 +22,121 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ConnectionStartOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ConnectionStartOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public FieldTable getClientProperties(); + public static final int CLASS_ID = 10; + public static final int METHOD_ID = 11; + + // Fields declared in specification + private final FieldTable _clientProperties; // [clientProperties] + private final AMQShortString _mechanism; // [mechanism] + private final byte[] _response; // [response] + private final AMQShortString _locale; // [locale] + + public ConnectionStartOkBody( + FieldTable clientProperties, + AMQShortString mechanism, + byte[] response, + AMQShortString locale + ) + { + _clientProperties = clientProperties; + _mechanism = mechanism; + _response = response; + _locale = locale; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final FieldTable getClientProperties() + { + return _clientProperties; + } + public final AMQShortString getMechanism() + { + return _mechanism; + } + public final byte[] getResponse() + { + return _response; + } + public final AMQShortString getLocale() + { + return _locale; + } + + protected int getBodySize() + { + int size = 0; + size += getSizeOf( _clientProperties ); + size += getSizeOf( _mechanism ); + size += getSizeOf( _response ); + size += getSizeOf( _locale ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeFieldTable( buffer, _clientProperties ); + writeAMQShortString( buffer, _mechanism ); + writeBytes( buffer, _response ); + writeAMQShortString( buffer, _locale ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchConnectionStartOk(this, channelId); + } - public AMQShortString getLocale(); + public String toString() + { + StringBuilder buf = new StringBuilder("[ConnectionStartOkBodyImpl: "); + buf.append( "clientProperties=" ); + buf.append( getClientProperties() ); + buf.append( ", " ); + buf.append( "mechanism=" ); + buf.append( getMechanism() ); + buf.append( ", " ); + buf.append( "response=" ); + buf.append( getResponse() == null ? "null" : java.util.Arrays.toString( getResponse() ) ); + buf.append( ", " ); + buf.append( "locale=" ); + buf.append( getLocale() ); + buf.append("]"); + return buf.toString(); + } - public AMQShortString getMechanism(); + public static void process(final MarkableDataInput in, final ServerMethodProcessor dispatcher) + throws IOException, AMQFrameDecodingException + { - public byte[] getResponse(); + FieldTable clientProperties = EncodingUtils.readFieldTable(in); + AMQShortString mechanism = in.readAMQShortString(); + byte[] response = EncodingUtils.readBytes(in); + AMQShortString locale = in.readAMQShortString(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveConnectionStartOk(clientProperties, mechanism, response, locale); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionTuneBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionTuneBody.java index 82a1b2f04b..04def21d44 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionTuneBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionTuneBody.java @@ -22,19 +22,112 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ConnectionTuneBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ConnectionTuneBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public int getChannelMax(); + public static final int CLASS_ID = 10; + public static final int METHOD_ID = 30; + + // Fields declared in specification + private final int _channelMax; // [channelMax] + private final long _frameMax; // [frameMax] + private final int _heartbeat; // [heartbeat] + + // Constructor + public ConnectionTuneBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _channelMax = buffer.readUnsignedShort(); + _frameMax = EncodingUtils.readUnsignedInteger(buffer); + _heartbeat = buffer.readUnsignedShort(); + } + + public ConnectionTuneBody( + int channelMax, + long frameMax, + int heartbeat + ) + { + _channelMax = channelMax; + _frameMax = frameMax; + _heartbeat = heartbeat; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getChannelMax() + { + return _channelMax; + } + public final long getFrameMax() + { + return _frameMax; + } + public final int getHeartbeat() + { + return _heartbeat; + } + + protected int getBodySize() + { + int size = 8; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _channelMax ); + writeUnsignedInteger( buffer, _frameMax ); + writeUnsignedShort( buffer, _heartbeat ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchConnectionTune(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[ConnectionTuneBodyImpl: "); + buf.append( "channelMax=" ); + buf.append( getChannelMax() ); + buf.append( ", " ); + buf.append( "frameMax=" ); + buf.append( getFrameMax() ); + buf.append( ", " ); + buf.append( "heartbeat=" ); + buf.append( getHeartbeat() ); + buf.append("]"); + return buf.toString(); + } - public long getFrameMax(); + public static void process(final MarkableDataInput buffer, final ClientMethodProcessor dispatcher) throws IOException + { - public int getHeartbeat(); + int channelMax = buffer.readUnsignedShort(); + long frameMax = EncodingUtils.readUnsignedInteger(buffer); + int heartbeat = buffer.readUnsignedShort(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveConnectionTune(channelMax, frameMax, heartbeat); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionTuneOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionTuneOkBody.java index 15cdd44c08..3141a85766 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionTuneOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ConnectionTuneOkBody.java @@ -22,19 +22,112 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ConnectionTuneOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ConnectionTuneOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public int getChannelMax(); + public static final int CLASS_ID = 10; + public static final int METHOD_ID = 31; + + // Fields declared in specification + private final int _channelMax; // [channelMax] + private final long _frameMax; // [frameMax] + private final int _heartbeat; // [heartbeat] + + // Constructor + public ConnectionTuneOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _channelMax = buffer.readUnsignedShort(); + _frameMax = EncodingUtils.readUnsignedInteger(buffer); + _heartbeat = buffer.readUnsignedShort(); + } + + public ConnectionTuneOkBody( + int channelMax, + long frameMax, + int heartbeat + ) + { + _channelMax = channelMax; + _frameMax = frameMax; + _heartbeat = heartbeat; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getChannelMax() + { + return _channelMax; + } + public final long getFrameMax() + { + return _frameMax; + } + public final int getHeartbeat() + { + return _heartbeat; + } + + protected int getBodySize() + { + int size = 8; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _channelMax ); + writeUnsignedInteger( buffer, _frameMax ); + writeUnsignedShort( buffer, _heartbeat ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchConnectionTuneOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[ConnectionTuneOkBodyImpl: "); + buf.append( "channelMax=" ); + buf.append( getChannelMax() ); + buf.append( ", " ); + buf.append( "frameMax=" ); + buf.append( getFrameMax() ); + buf.append( ", " ); + buf.append( "heartbeat=" ); + buf.append( getHeartbeat() ); + buf.append("]"); + return buf.toString(); + } - public long getFrameMax(); + public static void process(final MarkableDataInput buffer, final ServerMethodProcessor dispatcher) throws IOException + { - public int getHeartbeat(); + int channelMax = buffer.readUnsignedShort(); + long frameMax = EncodingUtils.readUnsignedInteger(buffer); + int heartbeat = buffer.readUnsignedShort(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveConnectionTuneOk(channelMax, frameMax, heartbeat); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/Content.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/Content.java deleted file mode 100644 index e5feeec2a4..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/Content.java +++ /dev/null @@ -1,26 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.framing; - -public interface Content -{ - // TODO: New Content class required for AMQP 0-9. -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentBody.java index 6d6ec708d0..4d9826d83c 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentBody.java @@ -20,15 +20,15 @@ */ package org.apache.qpid.framing; -import org.apache.qpid.AMQException; -import org.apache.qpid.protocol.AMQVersionAwareProtocolSession; - import java.io.DataInput; -import java.io.DataInputStream; import java.io.DataOutput; import java.io.IOException; import java.nio.ByteBuffer; +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; +import org.apache.qpid.protocol.AMQVersionAwareProtocolSession; + public class ContentBody implements AMQBody { public static final byte TYPE = 3; @@ -72,23 +72,20 @@ public class ContentBody implements AMQBody session.contentBodyReceived(channelId, this); } - protected void populateFromBuffer(DataInputStream buffer, long size) throws AMQFrameDecodingException, IOException + public byte[] getPayload() { - if (size > 0) - { - _payload = new byte[(int)size]; - buffer.read(getPayload()); - } - + return _payload; } - public void reduceBufferToFit() + public static void process(final MarkableDataInput in, + final ChannelMethodProcessor methodProcessor, final long bodySize) + throws IOException { - } - public byte[] getPayload() - { - return _payload; + byte[] payload = new byte[(int)bodySize]; + in.readFully(payload); + + methodProcessor.receiveMessageContent(payload); } private static class BufferContentBody implements AMQBody diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentBodyFactory.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentBodyFactory.java deleted file mode 100644 index 10df105ee6..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentBodyFactory.java +++ /dev/null @@ -1,50 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.framing; - -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import org.apache.qpid.codec.MarkableDataInput; - -import java.io.IOException; - -public class ContentBodyFactory implements BodyFactory -{ - private static final Logger _log = LoggerFactory.getLogger(AMQMethodBodyFactory.class); - - private static final ContentBodyFactory _instance = new ContentBodyFactory(); - - public static ContentBodyFactory getInstance() - { - return _instance; - } - - private ContentBodyFactory() - { - _log.debug("Creating content body factory"); - } - - public AMQBody createBody(MarkableDataInput in, long bodySize) throws AMQFrameDecodingException, IOException - { - return new ContentBody(in, bodySize); - } -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java index f2a443d5fd..0d25e4dfba 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java @@ -20,54 +20,45 @@ */ package org.apache.qpid.framing; -import org.apache.qpid.AMQException; -import org.apache.qpid.protocol.AMQVersionAwareProtocolSession; - import java.io.DataInput; import java.io.DataInputStream; import java.io.DataOutput; import java.io.IOException; +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; +import org.apache.qpid.protocol.AMQVersionAwareProtocolSession; + public class ContentHeaderBody implements AMQBody { public static final byte TYPE = 2; + public static final int CLASS_ID = 60; - private int classId; - - private int weight; - - private long bodySize; + private long _bodySize; /** must never be null */ - private BasicContentHeaderProperties properties; - - public ContentHeaderBody() - { - } + private BasicContentHeaderProperties _properties; public ContentHeaderBody(DataInput buffer, long size) throws AMQFrameDecodingException, IOException { - classId = buffer.readUnsignedShort(); - weight = buffer.readUnsignedShort(); - bodySize = buffer.readLong(); + buffer.readUnsignedShort(); + buffer.readUnsignedShort(); + _bodySize = buffer.readLong(); int propertyFlags = buffer.readUnsignedShort(); ContentHeaderPropertiesFactory factory = ContentHeaderPropertiesFactory.getInstance(); - properties = factory.createContentHeaderProperties(classId, propertyFlags, buffer, (int)size - 14); + _properties = factory.createContentHeaderProperties(CLASS_ID, propertyFlags, buffer, (int)size - 14); } - - public ContentHeaderBody(BasicContentHeaderProperties props, int classId) + public ContentHeaderBody(BasicContentHeaderProperties props) { - properties = props; - this.classId = classId; + _properties = props; } - public ContentHeaderBody(int classId, int weight, BasicContentHeaderProperties props, long bodySize) + public ContentHeaderBody(BasicContentHeaderProperties props, long bodySize) { - this(props, classId); - this.weight = weight; - this.bodySize = bodySize; + _properties = props; + _bodySize = bodySize; } public byte getFrameType() @@ -95,16 +86,16 @@ public class ContentHeaderBody implements AMQBody public int getSize() { - return 2 + 2 + 8 + 2 + properties.getPropertyListSize(); + return 2 + 2 + 8 + 2 + _properties.getPropertyListSize(); } public void writePayload(DataOutput buffer) throws IOException { - EncodingUtils.writeUnsignedShort(buffer, classId); - EncodingUtils.writeUnsignedShort(buffer, weight); - buffer.writeLong(bodySize); - EncodingUtils.writeUnsignedShort(buffer, properties.getPropertyFlags()); - properties.writePropertyListPayload(buffer); + EncodingUtils.writeUnsignedShort(buffer, CLASS_ID); + EncodingUtils.writeUnsignedShort(buffer, 0); + buffer.writeLong(_bodySize); + EncodingUtils.writeUnsignedShort(buffer, _properties.getPropertyFlags()); + _properties.writePropertyListPayload(buffer); } public void handle(final int channelId, final AMQVersionAwareProtocolSession session) @@ -113,46 +104,42 @@ public class ContentHeaderBody implements AMQBody session.contentHeaderReceived(channelId, this); } - public static AMQFrame createAMQFrame(int channelId, int classId, int weight, BasicContentHeaderProperties properties, + public static AMQFrame createAMQFrame(int channelId, + BasicContentHeaderProperties properties, long bodySize) { - return new AMQFrame(channelId, new ContentHeaderBody(classId, weight, properties, bodySize)); - } - - public static AMQFrame createAMQFrame(int channelId, ContentHeaderBody body) - { - return new AMQFrame(channelId, body); + return new AMQFrame(channelId, new ContentHeaderBody(properties, bodySize)); } public BasicContentHeaderProperties getProperties() { - return properties; + return _properties; } public void setProperties(BasicContentHeaderProperties props) { - properties = props; + _properties = props; } @Override public String toString() { return "ContentHeaderBody{" + - "classId=" + classId + - ", weight=" + weight + - ", bodySize=" + bodySize + - ", properties=" + properties + + "classId=" + CLASS_ID + + ", weight=" + 0 + + ", bodySize=" + _bodySize + + ", properties=" + _properties + '}'; } public int getClassId() { - return classId; + return CLASS_ID; } public int getWeight() { - return weight; + return 0; } /** unsigned long but java can't handle that anyway when allocating byte array @@ -160,11 +147,33 @@ public class ContentHeaderBody implements AMQBody * @return the body size */ public long getBodySize() { - return bodySize; + return _bodySize; } public void setBodySize(long bodySize) { - this.bodySize = bodySize; + _bodySize = bodySize; + } + + public static void process(final MarkableDataInput buffer, + final ChannelMethodProcessor methodProcessor, final long size) + throws IOException, AMQFrameDecodingException + { + + int classId = buffer.readUnsignedShort(); + buffer.readUnsignedShort(); + long bodySize = buffer.readLong(); + int propertyFlags = buffer.readUnsignedShort(); + + BasicContentHeaderProperties properties; + + if (classId != CLASS_ID) + { + throw new AMQFrameDecodingException(null, "Unsupported content header class id: " + classId, null); + } + properties = new BasicContentHeaderProperties(); + properties.populatePropertiesFromBuffer(buffer, propertyFlags, (int)(size-14)); + + methodProcessor.receiveMessageHeader(properties, bodySize); } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBodyFactory.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBodyFactory.java deleted file mode 100644 index 83a5211013..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBodyFactory.java +++ /dev/null @@ -1,52 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.framing; - -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import org.apache.qpid.codec.MarkableDataInput; - -import java.io.IOException; - -public class ContentHeaderBodyFactory implements BodyFactory -{ - private static final Logger _log = LoggerFactory.getLogger(AMQMethodBodyFactory.class); - - private static final ContentHeaderBodyFactory _instance = new ContentHeaderBodyFactory(); - - public static ContentHeaderBodyFactory getInstance() - { - return _instance; - } - - private ContentHeaderBodyFactory() - { - _log.debug("Creating content header body factory"); - } - - public AMQBody createBody(MarkableDataInput in, long bodySize) throws AMQFrameDecodingException, IOException - { - // all content headers are the same - it is only the properties that differ. - // the content header body further delegates construction of properties - return new ContentHeaderBody(in, bodySize); - } -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderPropertiesFactory.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderPropertiesFactory.java index 55961db06b..e8eb471284 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderPropertiesFactory.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderPropertiesFactory.java @@ -20,8 +20,6 @@ */ package org.apache.qpid.framing; -import org.apache.qpid.framing.amqp_8_0.BasicConsumeBodyImpl; - import java.io.DataInput; import java.io.IOException; @@ -46,7 +44,7 @@ public class ContentHeaderPropertiesFactory // AMQP version change: "Hardwired" version to major=8, minor=0 // TODO: Change so that the actual version is obtained from // the ProtocolInitiation object for this session. - if (classId == BasicConsumeBodyImpl.CLASS_ID) + if (classId == BasicConsumeBody.CLASS_ID) { properties = new BasicContentHeaderProperties(); } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/DtxSelectBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/DtxSelectBody.java deleted file mode 100644 index d6d7c87e23..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/DtxSelectBody.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface DtxSelectBody extends EncodableAMQDataBlock, AMQMethodBody -{ -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/DtxSelectOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/DtxSelectOkBody.java deleted file mode 100644 index 9ea4585b35..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/DtxSelectOkBody.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface DtxSelectOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/DtxStartBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/DtxStartBody.java deleted file mode 100644 index e721bfcdd1..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/DtxStartBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface DtxStartBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getDtxIdentifier(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/DtxStartOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/DtxStartOkBody.java deleted file mode 100644 index c16e9d7447..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/DtxStartOkBody.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface DtxStartOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java index f0dcad4916..a7fe4b01f3 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java @@ -20,15 +20,15 @@ */ package org.apache.qpid.framing; -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - import java.io.DataInput; import java.io.DataOutput; import java.io.IOException; import java.nio.ByteBuffer; import java.nio.charset.Charset; +import org.slf4j.Logger; +import org.slf4j.LoggerFactory; + public class EncodingUtils { private static final Logger _logger = LoggerFactory.getLogger(EncodingUtils.class); @@ -218,12 +218,6 @@ public class EncodingUtils } } - public static int encodedContentLength(Content table) - { - // TODO: New Content class required for AMQP 0-9. - return 0; - } - public static void writeShortStringBytes(DataOutput buffer, String s) throws IOException { if (s != null) @@ -374,11 +368,6 @@ public class EncodingUtils } } - public static void writeContentBytes(DataOutput buffer, Content content) - { - // TODO: New Content class required for AMQP 0-9. - } - public static void writeBooleans(DataOutput buffer, boolean[] values) throws IOException { byte packedValue = 0; @@ -656,12 +645,6 @@ public class EncodingUtils } } - public static Content readContent(DataInput buffer) throws AMQFrameDecodingException - { - // TODO: New Content class required for AMQP 0-9. - return null; - } - public static AMQShortString readAMQShortString(DataInput buffer) throws IOException { return AMQShortString.readFromBuffer(buffer); @@ -955,7 +938,6 @@ public class EncodingUtils } else { - // really writing out unsigned byte writeUnsignedInteger(buffer, 0L); } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeBoundBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeBoundBody.java index fa1fb441a8..e8dc2ae442 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeBoundBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeBoundBody.java @@ -22,19 +22,117 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ExchangeBoundBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ExchangeBoundBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public AMQShortString getExchange(); + public static final int CLASS_ID = 40; + public static final int METHOD_ID = 22; + + // Fields declared in specification + private final AMQShortString _exchange; // [exchange] + private final AMQShortString _routingKey; // [routingKey] + private final AMQShortString _queue; // [queue] + + // Constructor + public ExchangeBoundBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _exchange = buffer.readAMQShortString(); + _routingKey = buffer.readAMQShortString(); + _queue = buffer.readAMQShortString(); + } + + public ExchangeBoundBody( + AMQShortString exchange, + AMQShortString routingKey, + AMQShortString queue + ) + { + _exchange = exchange; + _routingKey = routingKey; + _queue = queue; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final AMQShortString getExchange() + { + return _exchange; + } + public final AMQShortString getRoutingKey() + { + return _routingKey; + } + public final AMQShortString getQueue() + { + return _queue; + } + + protected int getBodySize() + { + int size = 0; + size += getSizeOf( _exchange ); + size += getSizeOf( _routingKey ); + size += getSizeOf( _queue ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeAMQShortString( buffer, _exchange ); + writeAMQShortString( buffer, _routingKey ); + writeAMQShortString( buffer, _queue ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchExchangeBound(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[ExchangeBoundBodyImpl: "); + buf.append( "exchange=" ); + buf.append( getExchange() ); + buf.append( ", " ); + buf.append( "routingKey=" ); + buf.append( getRoutingKey() ); + buf.append( ", " ); + buf.append( "queue=" ); + buf.append( getQueue() ); + buf.append("]"); + return buf.toString(); + } - public AMQShortString getQueue(); + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) + throws IOException + { - public AMQShortString getRoutingKey(); + AMQShortString exchange = buffer.readAMQShortString(); + AMQShortString routingKey = buffer.readAMQShortString(); + AMQShortString queue = buffer.readAMQShortString(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveExchangeBound(exchange, routingKey, queue); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeBoundOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeBoundOkBody.java index 7a60e4dc21..ef91c1d635 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeBoundOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeBoundOkBody.java @@ -22,17 +22,109 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ExchangeBoundOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ExchangeBoundOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public int getReplyCode(); + public static final int CLASS_ID = 40; + public static final int METHOD_ID = 23; + public static final int OK = 0; + public static final int EXCHANGE_NOT_FOUND = 1; + public static final int QUEUE_NOT_FOUND = 2; + public static final int NO_BINDINGS = 3; + public static final int QUEUE_NOT_BOUND = 4; + public static final int NO_QUEUE_BOUND_WITH_RK = 5; + public static final int SPECIFIC_QUEUE_NOT_BOUND_WITH_RK = 6; + + // Fields declared in specification + private final int _replyCode; // [replyCode] + private final AMQShortString _replyText; // [replyText] + + // Constructor + public ExchangeBoundOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _replyCode = buffer.readUnsignedShort(); + _replyText = buffer.readAMQShortString(); + } + + public ExchangeBoundOkBody( + int replyCode, + AMQShortString replyText + ) + { + _replyCode = replyCode; + _replyText = replyText; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getReplyCode() + { + return _replyCode; + } + public final AMQShortString getReplyText() + { + return _replyText; + } + + protected int getBodySize() + { + int size = 2; + size += getSizeOf( _replyText ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _replyCode ); + writeAMQShortString( buffer, _replyText ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchExchangeBoundOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[ExchangeBoundOkBodyImpl: "); + buf.append( "replyCode=" ); + buf.append( getReplyCode() ); + buf.append( ", " ); + buf.append( "replyText=" ); + buf.append( getReplyText() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput buffer, + final ClientChannelMethodProcessor dispatcher) + throws IOException + { - public AMQShortString getReplyText(); + int replyCode = buffer.readUnsignedShort(); + AMQShortString replyText = buffer.readAMQShortString(); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveExchangeBoundOk(replyCode, replyText); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeclareBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeclareBody.java index 8ffb998e47..4001ba7aa0 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeclareBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeclareBody.java @@ -22,31 +22,212 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ExchangeDeclareBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ExchangeDeclareBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public FieldTable getArguments(); + public static final int CLASS_ID = 40; + public static final int METHOD_ID = 10; + + // Fields declared in specification + private final int _ticket; // [ticket] + private final AMQShortString _exchange; // [exchange] + private final AMQShortString _type; // [type] + private final byte _bitfield0; // [passive, durable, autoDelete, internal, nowait] + private final FieldTable _arguments; // [arguments] + + // Constructor + public ExchangeDeclareBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _ticket = buffer.readUnsignedShort(); + _exchange = buffer.readAMQShortString(); + _type = buffer.readAMQShortString(); + _bitfield0 = buffer.readByte(); + _arguments = EncodingUtils.readFieldTable(buffer); + } + + public ExchangeDeclareBody( + int ticket, + AMQShortString exchange, + AMQShortString type, + boolean passive, + boolean durable, + boolean autoDelete, + boolean internal, + boolean nowait, + FieldTable arguments + ) + { + _ticket = ticket; + _exchange = exchange; + _type = type; + byte bitfield0 = (byte)0; + if( passive ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + + if( durable ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); + } + + if( autoDelete ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); + } + + if( internal ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); + } + + if( nowait ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 4)); + } + + _bitfield0 = bitfield0; + _arguments = arguments; + } + + public int getClazz() + { + return CLASS_ID; + } - public boolean getAutoDelete(); + public int getMethod() + { + return METHOD_ID; + } - public boolean getDurable(); + public final int getTicket() + { + return _ticket; + } + public final AMQShortString getExchange() + { + return _exchange; + } + public final AMQShortString getType() + { + return _type; + } + public final boolean getPassive() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + public final boolean getDurable() + { + return (((int)(_bitfield0)) & ( 1 << 1)) != 0; + } + public final boolean getAutoDelete() + { + return (((int)(_bitfield0)) & ( 1 << 2)) != 0; + } + public final boolean getInternal() + { + return (((int)(_bitfield0)) & ( 1 << 3)) != 0; + } + public final boolean getNowait() + { + return (((int)(_bitfield0)) & ( 1 << 4)) != 0; + } + public final FieldTable getArguments() + { + return _arguments; + } - public AMQShortString getExchange(); + protected int getBodySize() + { + int size = 3; + size += getSizeOf( _exchange ); + size += getSizeOf( _type ); + size += getSizeOf( _arguments ); + return size; + } - public boolean getInternal(); + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _ticket ); + writeAMQShortString( buffer, _exchange ); + writeAMQShortString( buffer, _type ); + writeBitfield( buffer, _bitfield0 ); + writeFieldTable( buffer, _arguments ); + } - public boolean getNowait(); + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchExchangeDeclare(this, channelId); + } - public boolean getPassive(); + public String toString() + { + StringBuilder buf = new StringBuilder("[ExchangeDeclareBodyImpl: "); + buf.append( "ticket=" ); + buf.append( getTicket() ); + buf.append( ", " ); + buf.append( "exchange=" ); + buf.append( getExchange() ); + buf.append( ", " ); + buf.append( "type=" ); + buf.append( getType() ); + buf.append( ", " ); + buf.append( "passive=" ); + buf.append( getPassive() ); + buf.append( ", " ); + buf.append( "durable=" ); + buf.append( getDurable() ); + buf.append( ", " ); + buf.append( "autoDelete=" ); + buf.append( getAutoDelete() ); + buf.append( ", " ); + buf.append( "internal=" ); + buf.append( getInternal() ); + buf.append( ", " ); + buf.append( "nowait=" ); + buf.append( getNowait() ); + buf.append( ", " ); + buf.append( "arguments=" ); + buf.append( getArguments() ); + buf.append("]"); + return buf.toString(); + } - public int getTicket(); + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) throws IOException, AMQFrameDecodingException + { - public AMQShortString getType(); + int ticket = buffer.readUnsignedShort(); + AMQShortString exchange = buffer.readAMQShortString(); + AMQShortString type = buffer.readAMQShortString(); + byte bitfield = buffer.readByte(); + boolean passive = (bitfield & 0x1) == 0x1; + boolean durable = (bitfield & 0x2) == 0x2; + boolean autoDelete = (bitfield & 0x4) == 0x4; + boolean internal = (bitfield & 0x8) == 0x8; + boolean nowait = (bitfield & 0x10) == 0x10; + FieldTable arguments = EncodingUtils.readFieldTable(buffer); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveExchangeDeclare(exchange, + type, + passive, + durable, + autoDelete, + internal, + nowait, + arguments); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeclareOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeclareOkBody.java index 848963ce1b..68b193cfb0 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeclareOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeclareOkBody.java @@ -22,13 +22,66 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ExchangeDeclareOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ExchangeDeclareOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + + public static final int CLASS_ID = 40; + public static final int METHOD_ID = 11; + + // Fields declared in specification + + // Constructor + public ExchangeDeclareOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + } + + public ExchangeDeclareOkBody( + ) + { + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + + protected int getBodySize() + { + int size = 0; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchExchangeDeclareOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[ExchangeDeclareOkBodyImpl: "); + buf.append("]"); + return buf.toString(); + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeleteBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeleteBody.java index 5ce3a7415f..f4646315cd 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeleteBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeleteBody.java @@ -22,21 +22,135 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ExchangeDeleteBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ExchangeDeleteBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public AMQShortString getExchange(); + public static final int CLASS_ID = 40; + public static final int METHOD_ID = 20; + + // Fields declared in specification + private final int _ticket; // [ticket] + private final AMQShortString _exchange; // [exchange] + private final byte _bitfield0; // [ifUnused, nowait] + + // Constructor + public ExchangeDeleteBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _ticket = buffer.readUnsignedShort(); + _exchange = buffer.readAMQShortString(); + _bitfield0 = buffer.readByte(); + } + + public ExchangeDeleteBody( + int ticket, + AMQShortString exchange, + boolean ifUnused, + boolean nowait + ) + { + _ticket = ticket; + _exchange = exchange; + byte bitfield0 = (byte)0; + if( ifUnused ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + + if( nowait ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); + } + _bitfield0 = bitfield0; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getTicket() + { + return _ticket; + } + public final AMQShortString getExchange() + { + return _exchange; + } + public final boolean getIfUnused() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + public final boolean getNowait() + { + return (((int)(_bitfield0)) & ( 1 << 1)) != 0; + } + + protected int getBodySize() + { + int size = 3; + size += getSizeOf( _exchange ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _ticket ); + writeAMQShortString( buffer, _exchange ); + writeBitfield( buffer, _bitfield0 ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchExchangeDelete(this, channelId); + } - public boolean getIfUnused(); + public String toString() + { + StringBuilder buf = new StringBuilder("[ExchangeDeleteBodyImpl: "); + buf.append( "ticket=" ); + buf.append( getTicket() ); + buf.append( ", " ); + buf.append( "exchange=" ); + buf.append( getExchange() ); + buf.append( ", " ); + buf.append( "ifUnused=" ); + buf.append( getIfUnused() ); + buf.append( ", " ); + buf.append( "nowait=" ); + buf.append( getNowait() ); + buf.append("]"); + return buf.toString(); + } - public boolean getNowait(); + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) + throws IOException + { - public int getTicket(); + int ticket = buffer.readUnsignedShort(); + AMQShortString exchange = buffer.readAMQShortString(); + byte bitfield = buffer.readByte(); + boolean ifUnused = (bitfield & 0x01) == 0x01; + boolean nowait = (bitfield & 0x02) == 0x02; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveExchangeDelete(exchange, ifUnused, nowait); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeleteOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeleteOkBody.java index 54ce0940d5..7af0b02ef0 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeleteOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ExchangeDeleteOkBody.java @@ -22,13 +22,66 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface ExchangeDeleteOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class ExchangeDeleteOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + + public static final int CLASS_ID = 40; + public static final int METHOD_ID = 21; + + // Fields declared in specification + + // Constructor + public ExchangeDeleteOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + } + + public ExchangeDeleteOkBody( + ) + { + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + + protected int getBodySize() + { + int size = 0; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchExchangeDeleteOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[ExchangeDeleteOkBodyImpl: "); + buf.append("]"); + return buf.toString(); + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileAckBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/FileAckBody.java deleted file mode 100644 index 9d5f186521..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileAckBody.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface FileAckBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public long getDeliveryTag(); - - public boolean getMultiple(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileCancelBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/FileCancelBody.java deleted file mode 100644 index ac85455ff5..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileCancelBody.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface FileCancelBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getConsumerTag(); - - public boolean getNowait(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileCancelOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/FileCancelOkBody.java deleted file mode 100644 index 40364887c8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileCancelOkBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface FileCancelOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getConsumerTag(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileConsumeOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/FileConsumeOkBody.java deleted file mode 100644 index dd6dd3f64b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileConsumeOkBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface FileConsumeOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getConsumerTag(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileOpenBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/FileOpenBody.java deleted file mode 100644 index 25ea3834bc..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileOpenBody.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface FileOpenBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public long getContentSize(); - - public AMQShortString getIdentifier(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileOpenOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/FileOpenOkBody.java deleted file mode 100644 index 4edff34eb4..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileOpenOkBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface FileOpenOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public long getStagedSize(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileQosBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/FileQosBody.java deleted file mode 100644 index 378b6a3b5d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileQosBody.java +++ /dev/null @@ -1,40 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface FileQosBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public boolean getGlobal(); - - public int getPrefetchCount(); - - public long getPrefetchSize(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileQosOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/FileQosOkBody.java deleted file mode 100644 index 7296b36cc2..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileQosOkBody.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface FileQosOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileRejectBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/FileRejectBody.java deleted file mode 100644 index c569d8ed9f..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileRejectBody.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface FileRejectBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public long getDeliveryTag(); - - public boolean getRequeue(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileReturnBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/FileReturnBody.java deleted file mode 100644 index 8bd5825141..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileReturnBody.java +++ /dev/null @@ -1,42 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface FileReturnBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getExchange(); - - public int getReplyCode(); - - public AMQShortString getReplyText(); - - public AMQShortString getRoutingKey(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileStageBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/FileStageBody.java deleted file mode 100644 index 976fa3b0da..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileStageBody.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface FileStageBody extends EncodableAMQDataBlock, AMQMethodBody -{ -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FrameCreatingMethodProcessor.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/FrameCreatingMethodProcessor.java new file mode 100644 index 0000000000..19b091a359 --- /dev/null +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/FrameCreatingMethodProcessor.java @@ -0,0 +1,611 @@ +/* + * + * 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.framing; + +import java.util.ArrayList; +import java.util.List; + +public class FrameCreatingMethodProcessor implements MethodProcessor<FrameCreatingMethodProcessor.ClientAndServerChannelMethodProcessor>, + ClientMethodProcessor<FrameCreatingMethodProcessor.ClientAndServerChannelMethodProcessor>, + ServerMethodProcessor<FrameCreatingMethodProcessor.ClientAndServerChannelMethodProcessor> +{ + private ProtocolVersion _protocolVersion; + + private final List<AMQDataBlock> _processedMethods = new ArrayList<>(); + private int _classId; + private int _methodId; + + public FrameCreatingMethodProcessor(final ProtocolVersion protocolVersion) + { + _protocolVersion = protocolVersion; + } + + public List<AMQDataBlock> getProcessedMethods() + { + return _processedMethods; + } + + @Override + public void receiveConnectionStart(final short versionMajor, + final short versionMinor, + final FieldTable serverProperties, + final byte[] mechanisms, + final byte[] locales) + { + _processedMethods.add(new AMQFrame(0, new ConnectionStartBody(versionMajor, versionMinor, serverProperties, mechanisms, locales))); + } + + @Override + public void receiveConnectionStartOk(final FieldTable clientProperties, + final AMQShortString mechanism, + final byte[] response, + final AMQShortString locale) + { + _processedMethods.add(new AMQFrame(0, new ConnectionStartOkBody(clientProperties, mechanism, response, locale))); + } + + @Override + public void receiveConnectionSecure(final byte[] challenge) + { + _processedMethods.add(new AMQFrame(0, new ConnectionSecureBody(challenge))); + } + + @Override + public void receiveConnectionSecureOk(final byte[] response) + { + _processedMethods.add(new AMQFrame(0, new ConnectionSecureOkBody(response))); + } + + @Override + public void receiveConnectionTune(final int channelMax, final long frameMax, final int heartbeat) + { + _processedMethods.add(new AMQFrame(0, new ConnectionTuneBody(channelMax, frameMax, heartbeat))); + } + + @Override + public void receiveConnectionTuneOk(final int channelMax, final long frameMax, final int heartbeat) + { + _processedMethods.add(new AMQFrame(0, new ConnectionTuneOkBody(channelMax, frameMax, heartbeat))); + } + + @Override + public void receiveConnectionOpen(final AMQShortString virtualHost, + final AMQShortString capabilities, + final boolean insist) + { + _processedMethods.add(new AMQFrame(0, new ConnectionOpenBody(virtualHost, capabilities, insist))); + } + + @Override + public void receiveConnectionOpenOk(final AMQShortString knownHosts) + { + _processedMethods.add(new AMQFrame(0, new ConnectionOpenOkBody(knownHosts))); + } + + @Override + public void receiveConnectionRedirect(final AMQShortString host, final AMQShortString knownHosts) + { + _processedMethods.add(new AMQFrame(0, new ConnectionRedirectBody(getProtocolVersion(), host, knownHosts))); + } + + @Override + public void receiveConnectionClose(final int replyCode, + final AMQShortString replyText, + final int classId, + final int methodId) + { + _processedMethods.add(new AMQFrame(0, new ConnectionCloseBody(getProtocolVersion(), replyCode, replyText, classId, methodId))); + } + + @Override + public void receiveConnectionCloseOk() + { + _processedMethods.add(new AMQFrame(0, ProtocolVersion.v8_0.equals(getProtocolVersion()) + ? ConnectionCloseOkBody.CONNECTION_CLOSE_OK_0_8 + : ConnectionCloseOkBody.CONNECTION_CLOSE_OK_0_9)); + } + + @Override + public void receiveChannelOpen(final int channelId) + { + _processedMethods.add(new AMQFrame(channelId, new ChannelOpenBody())); + } + + private void receiveExchangeBoundOk(final int channelId, final int replyCode, final AMQShortString replyText) + { + _processedMethods.add(new AMQFrame(channelId, new ExchangeBoundOkBody(replyCode, replyText))); + } + + @Override + public void receiveHeartbeat() + { + _processedMethods.add(new AMQFrame(0, new HeartbeatBody())); + } + + @Override + public ProtocolVersion getProtocolVersion() + { + return _protocolVersion; + } + + @Override + public ClientAndServerChannelMethodProcessor getChannelMethodProcessor(final int channelId) + { + return new FrameCreatingChannelMethodProcessor(channelId); + } + + public void setProtocolVersion(final ProtocolVersion protocolVersion) + { + _protocolVersion = protocolVersion; + } + + @Override + public void receiveProtocolHeader(final ProtocolInitiation protocolInitiation) + { + _processedMethods.add(protocolInitiation); + } + + @Override + public void setCurrentMethod(final int classId, final int methodId) + { + _classId = classId; + _methodId = methodId; + } + + @Override + public boolean ignoreAllButCloseOk() + { + return false; + } + + public int getClassId() + { + return _classId; + } + + public int getMethodId() + { + return _methodId; + } + + public static interface ClientAndServerChannelMethodProcessor extends ServerChannelMethodProcessor, ClientChannelMethodProcessor + { + + } + + private class FrameCreatingChannelMethodProcessor implements ClientAndServerChannelMethodProcessor + { + private final int _channelId; + + private FrameCreatingChannelMethodProcessor(final int channelId) + { + _channelId = channelId; + } + + + @Override + public void receiveChannelOpenOk() + { + _processedMethods.add(new AMQFrame(_channelId, ProtocolVersion.v8_0.equals(getProtocolVersion()) + ? ChannelOpenOkBody.INSTANCE_0_8 + : ChannelOpenOkBody.INSTANCE_0_9)); + } + + @Override + public void receiveChannelAlert(final int replyCode, final AMQShortString replyText, final FieldTable details) + { + _processedMethods.add(new AMQFrame(_channelId, new ChannelAlertBody(replyCode, replyText, details))); + } + + @Override + public void receiveAccessRequestOk(final int ticket) + { + _processedMethods.add(new AMQFrame(_channelId, new AccessRequestOkBody(ticket))); + } + + @Override + public void receiveExchangeDeclareOk() + { + _processedMethods.add(new AMQFrame(_channelId, new ExchangeDeclareOkBody())); + } + + @Override + public void receiveExchangeDeleteOk() + { + _processedMethods.add(new AMQFrame(_channelId, new ExchangeDeleteOkBody())); + } + + @Override + public void receiveExchangeBoundOk(final int replyCode, final AMQShortString replyText) + { + FrameCreatingMethodProcessor.this.receiveExchangeBoundOk(_channelId, replyCode, replyText); + } + + @Override + public void receiveQueueBindOk() + { + _processedMethods.add(new AMQFrame(_channelId, new QueueBindOkBody())); + } + + @Override + public void receiveQueueUnbindOk() + { + _processedMethods.add(new AMQFrame(_channelId, new QueueUnbindOkBody())); + } + + @Override + public void receiveQueueDeclareOk(final AMQShortString queue, final long messageCount, final long consumerCount) + { + _processedMethods.add(new AMQFrame(_channelId, new QueueDeclareOkBody(queue, messageCount, consumerCount))); + } + + @Override + public void receiveQueuePurgeOk(final long messageCount) + { + _processedMethods.add(new AMQFrame(_channelId, new QueuePurgeOkBody(messageCount))); + } + + @Override + public void receiveQueueDeleteOk(final long messageCount) + { + _processedMethods.add(new AMQFrame(_channelId, new QueueDeleteOkBody(messageCount))); + } + + @Override + public void receiveBasicRecoverSyncOk() + { + _processedMethods.add(new AMQFrame(_channelId, new BasicRecoverSyncOkBody(getProtocolVersion()))); + } + + @Override + public void receiveBasicQosOk() + { + _processedMethods.add(new AMQFrame(_channelId, new BasicQosOkBody())); + } + + @Override + public void receiveBasicConsumeOk(final AMQShortString consumerTag) + { + _processedMethods.add(new AMQFrame(_channelId, new BasicConsumeOkBody(consumerTag))); + } + + @Override + public void receiveBasicCancelOk(final AMQShortString consumerTag) + { + _processedMethods.add(new AMQFrame(_channelId, new BasicCancelOkBody(consumerTag))); + } + + @Override + public void receiveBasicReturn(final int replyCode, + final AMQShortString replyText, + final AMQShortString exchange, + final AMQShortString routingKey) + { + _processedMethods.add(new AMQFrame(_channelId, new BasicReturnBody(replyCode, + replyText, + exchange, + routingKey))); + } + + @Override + public void receiveBasicDeliver(final AMQShortString consumerTag, + final long deliveryTag, + final boolean redelivered, + final AMQShortString exchange, + final AMQShortString routingKey) + { + _processedMethods.add(new AMQFrame(_channelId, new BasicDeliverBody(consumerTag, + deliveryTag, + redelivered, + exchange, + routingKey))); + } + + @Override + public void receiveBasicGetOk(final long deliveryTag, + final boolean redelivered, + final AMQShortString exchange, + final AMQShortString routingKey, + final long messageCount) + { + _processedMethods.add(new AMQFrame(_channelId, new BasicGetOkBody(deliveryTag, + redelivered, + exchange, + routingKey, + messageCount))); + } + + @Override + public void receiveBasicGetEmpty() + { + _processedMethods.add(new AMQFrame(_channelId, new BasicGetEmptyBody((AMQShortString)null))); + } + + @Override + public void receiveTxSelectOk() + { + _processedMethods.add(new AMQFrame(_channelId, TxSelectOkBody.INSTANCE)); + } + + @Override + public void receiveTxCommitOk() + { + _processedMethods.add(new AMQFrame(_channelId, TxCommitOkBody.INSTANCE)); + } + + @Override + public void receiveTxRollbackOk() + { + _processedMethods.add(new AMQFrame(_channelId, TxRollbackOkBody.INSTANCE)); + } + + @Override + public void receiveAccessRequest(final AMQShortString realm, + final boolean exclusive, + final boolean passive, + final boolean active, + final boolean write, + final boolean read) + { + _processedMethods.add(new AMQFrame(_channelId, new AccessRequestBody(realm, + exclusive, + passive, + active, + write, + read))); + } + + @Override + public void receiveExchangeDeclare(final AMQShortString exchange, + final AMQShortString type, + final boolean passive, + final boolean durable, + final boolean autoDelete, + final boolean internal, + final boolean nowait, + final FieldTable arguments) + { + _processedMethods.add(new AMQFrame(_channelId, new ExchangeDeclareBody(0, + exchange, + type, + passive, + durable, + autoDelete, + internal, + nowait, + arguments))); + } + + @Override + public void receiveExchangeDelete(final AMQShortString exchange, final boolean ifUnused, final boolean nowait) + { + _processedMethods.add(new AMQFrame(_channelId, new ExchangeDeleteBody(0, exchange, ifUnused, nowait))); + } + + @Override + public void receiveExchangeBound(final AMQShortString exchange, + final AMQShortString routingKey, + final AMQShortString queue) + { + _processedMethods.add(new AMQFrame(_channelId, new ExchangeBoundBody(exchange, routingKey, queue))); + } + + @Override + public void receiveQueueDeclare(final AMQShortString queue, + final boolean passive, + final boolean durable, + final boolean exclusive, + final boolean autoDelete, + final boolean nowait, + final FieldTable arguments) + { + _processedMethods.add(new AMQFrame(_channelId, new QueueDeclareBody(0, + queue, + passive, + durable, + exclusive, + autoDelete, + nowait, + arguments))); + } + + @Override + public void receiveQueueBind(final AMQShortString queue, + final AMQShortString exchange, + final AMQShortString bindingKey, + final boolean nowait, + final FieldTable arguments) + { + _processedMethods.add(new AMQFrame(_channelId, new QueueBindBody(0, + queue, + exchange, + bindingKey, + nowait, + arguments))); + } + + @Override + public void receiveQueuePurge(final AMQShortString queue, final boolean nowait) + { + _processedMethods.add(new AMQFrame(_channelId, new QueuePurgeBody(0, queue, nowait))); + } + + @Override + public void receiveQueueDelete(final AMQShortString queue, + final boolean ifUnused, + final boolean ifEmpty, + final boolean nowait) + { + _processedMethods.add(new AMQFrame(_channelId, new QueueDeleteBody(0, queue, ifUnused, ifEmpty, nowait))); + } + + @Override + public void receiveQueueUnbind(final AMQShortString queue, + final AMQShortString exchange, + final AMQShortString bindingKey, + final FieldTable arguments) + { + _processedMethods.add(new AMQFrame(_channelId, new QueueUnbindBody(0, + queue, + exchange, + bindingKey, + arguments))); + } + + @Override + public void receiveBasicRecover(final boolean requeue, final boolean sync) + { + if(ProtocolVersion.v8_0.equals(getProtocolVersion()) || !sync) + { + _processedMethods.add(new AMQFrame(_channelId, new BasicRecoverBody(requeue))); + } + else + { + _processedMethods.add(new AMQFrame(_channelId, new BasicRecoverSyncBody(getProtocolVersion(), requeue))); + } + } + + @Override + public void receiveBasicQos(final long prefetchSize, final int prefetchCount, final boolean global) + { + _processedMethods.add(new AMQFrame(_channelId, new BasicQosBody(prefetchSize, prefetchCount, global))); + } + + @Override + public void receiveBasicConsume(final AMQShortString queue, + final AMQShortString consumerTag, + final boolean noLocal, + final boolean noAck, + final boolean exclusive, + final boolean nowait, + final FieldTable arguments) + { + _processedMethods.add(new AMQFrame(_channelId, new BasicConsumeBody(0, + queue, + consumerTag, + noLocal, + noAck, + exclusive, + nowait, + arguments))); + } + + @Override + public void receiveBasicCancel(final AMQShortString consumerTag, final boolean noWait) + { + _processedMethods.add(new AMQFrame(_channelId, new BasicCancelBody(consumerTag, noWait))); + } + + @Override + public void receiveBasicPublish(final AMQShortString exchange, + final AMQShortString routingKey, + final boolean mandatory, + final boolean immediate) + { + _processedMethods.add(new AMQFrame(_channelId, new BasicPublishBody(0, + exchange, + routingKey, + mandatory, + immediate))); + } + + @Override + public void receiveBasicGet(final AMQShortString queue, final boolean noAck) + { + _processedMethods.add(new AMQFrame(_channelId, new BasicGetBody(0, queue, noAck))); + } + + @Override + public void receiveBasicAck(final long deliveryTag, final boolean multiple) + { + _processedMethods.add(new AMQFrame(_channelId, new BasicAckBody(deliveryTag, multiple))); + } + + @Override + public void receiveBasicReject(final long deliveryTag, final boolean requeue) + { + _processedMethods.add(new AMQFrame(_channelId, new BasicRejectBody(deliveryTag, requeue))); + } + + @Override + public void receiveTxSelect() + { + _processedMethods.add(new AMQFrame(_channelId, TxSelectBody.INSTANCE)); + } + + @Override + public void receiveTxCommit() + { + _processedMethods.add(new AMQFrame(_channelId, TxCommitBody.INSTANCE)); + } + + @Override + public void receiveTxRollback() + { + _processedMethods.add(new AMQFrame(_channelId, TxRollbackBody.INSTANCE)); + } + + @Override + public void receiveChannelFlow(final boolean active) + { + _processedMethods.add(new AMQFrame(_channelId, new ChannelFlowBody(active))); + } + + @Override + public void receiveChannelFlowOk(final boolean active) + { + _processedMethods.add(new AMQFrame(_channelId, new ChannelFlowOkBody(active))); + } + + @Override + public void receiveChannelClose(final int replyCode, + final AMQShortString replyText, + final int classId, + final int methodId) + { + _processedMethods.add(new AMQFrame(_channelId, new ChannelCloseBody(replyCode, replyText, classId, methodId))); + } + + @Override + public void receiveChannelCloseOk() + { + _processedMethods.add(new AMQFrame(_channelId, ChannelCloseOkBody.INSTANCE)); + } + + @Override + public void receiveMessageContent(final byte[] data) + { + _processedMethods.add(new AMQFrame(_channelId, new ContentBody(data))); + } + + @Override + public void receiveMessageHeader(final BasicContentHeaderProperties properties, final long bodySize) + { + _processedMethods.add(new AMQFrame(_channelId, new ContentHeaderBody(properties, bodySize))); + } + + @Override + public boolean ignoreAllButCloseOk() + { + return false; + } + } +} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/HeartbeatBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/HeartbeatBody.java index 1613cd055e..b5f854eb0e 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/HeartbeatBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/HeartbeatBody.java @@ -20,13 +20,14 @@ */ package org.apache.qpid.framing; -import org.apache.qpid.AMQException; -import org.apache.qpid.protocol.AMQVersionAwareProtocolSession; - import java.io.DataInputStream; import java.io.DataOutput; import java.io.IOException; +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; +import org.apache.qpid.protocol.AMQVersionAwareProtocolSession; + public class HeartbeatBody implements AMQBody { public static final byte TYPE = 8; @@ -79,4 +80,17 @@ public class HeartbeatBody implements AMQBody { return new AMQFrame(0, this); } + + public static void process(final int channel, + final MarkableDataInput in, + final MethodProcessor processor, + final long bodySize) throws IOException + { + + if(bodySize > 0) + { + in.skip(bodySize); + } + processor.receiveHeartbeat(); + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/HeartbeatBodyFactory.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/HeartbeatBodyFactory.java deleted file mode 100644 index 971caca41a..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/HeartbeatBodyFactory.java +++ /dev/null @@ -1,32 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.framing; - -import org.apache.qpid.codec.MarkableDataInput; - -public class HeartbeatBodyFactory implements BodyFactory -{ - public AMQBody createBody(MarkableDataInput in, long bodySize) throws AMQFrameDecodingException - { - return new HeartbeatBody(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageAppendBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageAppendBody.java deleted file mode 100644 index c981ad00f8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageAppendBody.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageAppendBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public byte[] getBytes(); - - public byte[] getReference(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageCancelBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageCancelBody.java deleted file mode 100644 index e440aca42f..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageCancelBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageCancelBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getDestination(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageCheckpointBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageCheckpointBody.java deleted file mode 100644 index 1cc6dc598b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageCheckpointBody.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageCheckpointBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getIdentifier(); - - public byte[] getReference(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageCloseBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageCloseBody.java deleted file mode 100644 index 6898edec00..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageCloseBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageCloseBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public byte[] getReference(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageConsumeBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageConsumeBody.java deleted file mode 100644 index 13fe4aec2b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageConsumeBody.java +++ /dev/null @@ -1,48 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageConsumeBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getDestination(); - - public boolean getExclusive(); - - public FieldTable getFilter(); - - public boolean getNoAck(); - - public boolean getNoLocal(); - - public AMQShortString getQueue(); - - public int getTicket(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageEmptyBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageEmptyBody.java deleted file mode 100644 index d4f1c6e02a..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageEmptyBody.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageEmptyBody extends EncodableAMQDataBlock, AMQMethodBody -{ -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageGetBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageGetBody.java deleted file mode 100644 index c2641679a8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageGetBody.java +++ /dev/null @@ -1,42 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageGetBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getDestination(); - - public boolean getNoAck(); - - public AMQShortString getQueue(); - - public int getTicket(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageOffsetBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageOffsetBody.java deleted file mode 100644 index 3b7d94ae2e..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageOffsetBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageOffsetBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public long getValue(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageOkBody.java deleted file mode 100644 index c349acd2bb..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageOkBody.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageOpenBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageOpenBody.java deleted file mode 100644 index da021bd42c..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageOpenBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageOpenBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public byte[] getReference(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/abstraction/MessagePublishInfoImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessagePublishInfo.java index 53c70c8d71..cc8f7eab58 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/abstraction/MessagePublishInfoImpl.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessagePublishInfo.java @@ -18,23 +18,21 @@ * under the License. * */ -package org.apache.qpid.framing.abstraction; +package org.apache.qpid.framing; -import org.apache.qpid.framing.AMQShortString; - -public class MessagePublishInfoImpl implements MessagePublishInfo +public final class MessagePublishInfo { private AMQShortString _exchange; private boolean _immediate; private boolean _mandatory; private AMQShortString _routingKey; - public MessagePublishInfoImpl() + public MessagePublishInfo() { } - public MessagePublishInfoImpl(AMQShortString exchange, boolean immediate, boolean mandatory, - AMQShortString routingKey) + public MessagePublishInfo(AMQShortString exchange, boolean immediate, boolean mandatory, + AMQShortString routingKey) { _exchange = exchange; _immediate = immediate; @@ -69,7 +67,7 @@ public class MessagePublishInfoImpl implements MessagePublishInfo public void setMandatory(boolean mandatory) { - _mandatory = mandatory; + _mandatory = mandatory; } public AMQShortString getRoutingKey() @@ -81,4 +79,5 @@ public class MessagePublishInfoImpl implements MessagePublishInfo { _routingKey = routingKey; } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageQosBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageQosBody.java deleted file mode 100644 index ecedcebcee..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageQosBody.java +++ /dev/null @@ -1,40 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageQosBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public boolean getGlobal(); - - public int getPrefetchCount(); - - public long getPrefetchSize(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageRecoverBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageRecoverBody.java deleted file mode 100644 index 37188d5dc9..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageRecoverBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageRecoverBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public boolean getRequeue(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageRejectBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageRejectBody.java deleted file mode 100644 index 3bd858c20d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageRejectBody.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageRejectBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public int getCode(); - - public AMQShortString getText(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageResumeBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageResumeBody.java deleted file mode 100644 index ef68b97c19..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageResumeBody.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageResumeBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getIdentifier(); - - public byte[] getReference(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageTransferBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageTransferBody.java deleted file mode 100644 index 11f8848431..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MessageTransferBody.java +++ /dev/null @@ -1,78 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface MessageTransferBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getAppId(); - - public FieldTable getApplicationHeaders(); - - public Content getBody(); - - public AMQShortString getContentEncoding(); - - public AMQShortString getContentType(); - - public AMQShortString getCorrelationId(); - - public short getDeliveryMode(); - - public AMQShortString getDestination(); - - public AMQShortString getExchange(); - - public long getExpiration(); - - public boolean getImmediate(); - - public AMQShortString getMessageId(); - - public short getPriority(); - - public boolean getRedelivered(); - - public AMQShortString getReplyTo(); - - public AMQShortString getRoutingKey(); - - public byte[] getSecurityToken(); - - public int getTicket(); - - public long getTimestamp(); - - public AMQShortString getTransactionId(); - - public long getTtl(); - - public AMQShortString getUserId(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileDeliverBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MethodProcessor.java index 3b8fa3fe79..62c0cd3c6d 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileDeliverBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/MethodProcessor.java @@ -18,29 +18,23 @@ * under the License. * */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - package org.apache.qpid.framing; -public interface FileDeliverBody extends EncodableAMQDataBlock, AMQMethodBody +public interface MethodProcessor<T extends ChannelMethodProcessor> { + ProtocolVersion getProtocolVersion(); + + T getChannelMethodProcessor(int channelId); - public AMQShortString getConsumerTag(); + void receiveConnectionClose(int replyCode, AMQShortString replyText, int classId, int methodId); - public long getDeliveryTag(); + void receiveConnectionCloseOk(); - public AMQShortString getExchange(); + void receiveHeartbeat(); - public AMQShortString getIdentifier(); + void receiveProtocolHeader(ProtocolInitiation protocolInitiation); - public boolean getRedelivered(); + void setCurrentMethod(int classId, int methodId); - public AMQShortString getRoutingKey(); + boolean ignoreAllButCloseOk(); } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/MethodRegistry.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/MethodRegistry.java index 84274ba3a6..45c198942b 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/MethodRegistry.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/MethodRegistry.java @@ -29,330 +29,529 @@ package org.apache.qpid.framing; -import java.io.IOException; +public final class MethodRegistry +{ + private ProtocolVersion _protocolVersion; -import org.apache.qpid.framing.abstraction.ProtocolVersionMethodConverter; -import org.apache.qpid.codec.MarkableDataInput; -import java.util.Map; -import java.util.HashMap; + public MethodRegistry(ProtocolVersion pv) + { + _protocolVersion = pv; + } + + public void setProtocolVersion(final ProtocolVersion protocolVersion) + { + _protocolVersion = protocolVersion; + } + public final AccessRequestBody createAccessRequestBody(final AMQShortString realm, + final boolean exclusive, + final boolean passive, + final boolean active, + final boolean write, + final boolean read) + { + return new AccessRequestBody(realm, + exclusive, + passive, + active, + write, + read); + } -public abstract class MethodRegistry -{ - private static final Map<ProtocolVersion, MethodRegistry> _registries = - new HashMap<ProtocolVersion, MethodRegistry>(); + public final AccessRequestOkBody createAccessRequestOkBody(final int ticket) + { + return new AccessRequestOkBody(ticket); + } + + + public final BasicQosBody createBasicQosBody(final long prefetchSize, + final int prefetchCount, + final boolean global) + { + return new BasicQosBody(prefetchSize, + prefetchCount, + global); + } + + public final BasicQosOkBody createBasicQosOkBody() + { + return new BasicQosOkBody(); + } + + public final BasicConsumeBody createBasicConsumeBody(final int ticket, + final AMQShortString queue, + final AMQShortString consumerTag, + final boolean noLocal, + final boolean noAck, + final boolean exclusive, + final boolean nowait, + final FieldTable arguments) + { + return new BasicConsumeBody(ticket, + queue, + consumerTag, + noLocal, + noAck, + exclusive, + nowait, + arguments); + } + + public final BasicConsumeOkBody createBasicConsumeOkBody(final AMQShortString consumerTag) + { + return new BasicConsumeOkBody(consumerTag); + } + + public final BasicCancelBody createBasicCancelBody(final AMQShortString consumerTag, + final boolean nowait) + { + return new BasicCancelBody(consumerTag, + nowait); + } + + public final BasicCancelOkBody createBasicCancelOkBody(final AMQShortString consumerTag) + { + return new BasicCancelOkBody(consumerTag); + } + + public final BasicPublishBody createBasicPublishBody(final int ticket, + final AMQShortString exchange, + final AMQShortString routingKey, + final boolean mandatory, + final boolean immediate) + { + return new BasicPublishBody(ticket, + exchange, + routingKey, + mandatory, + immediate); + } + + public final BasicReturnBody createBasicReturnBody(final int replyCode, + final AMQShortString replyText, + final AMQShortString exchange, + final AMQShortString routingKey) + { + return new BasicReturnBody(replyCode, + replyText, + exchange, + routingKey); + } + + public final BasicDeliverBody createBasicDeliverBody(final AMQShortString consumerTag, + final long deliveryTag, + final boolean redelivered, + final AMQShortString exchange, + final AMQShortString routingKey) + { + return new BasicDeliverBody(consumerTag, + deliveryTag, + redelivered, + exchange, + routingKey); + } + + public final BasicGetBody createBasicGetBody(final int ticket, + final AMQShortString queue, + final boolean noAck) + { + return new BasicGetBody(ticket, + queue, + noAck); + } + + public final BasicGetOkBody createBasicGetOkBody(final long deliveryTag, + final boolean redelivered, + final AMQShortString exchange, + final AMQShortString routingKey, + final long messageCount) + { + return new BasicGetOkBody(deliveryTag, + redelivered, + exchange, + routingKey, + messageCount); + } + + public final BasicGetEmptyBody createBasicGetEmptyBody(final AMQShortString clusterId) + { + return new BasicGetEmptyBody(clusterId); + } + + public final BasicAckBody createBasicAckBody(final long deliveryTag, + final boolean multiple) + { + return new BasicAckBody(deliveryTag, + multiple); + } + + public final BasicRejectBody createBasicRejectBody(final long deliveryTag, + final boolean requeue) + { + return new BasicRejectBody(deliveryTag, + requeue); + } + + public final BasicRecoverBody createBasicRecoverBody(final boolean requeue) + { + return new BasicRecoverBody(requeue); + } + + + public final BasicRecoverSyncOkBody createBasicRecoverSyncOkBody() + { + return new BasicRecoverSyncOkBody(_protocolVersion); + } + + + public final BasicRecoverSyncBody createBasicRecoverSyncBody(final boolean requeue) + { + return new BasicRecoverSyncBody(_protocolVersion, requeue); + } + + public final ChannelAlertBody createChannelAlertBody(final int replyCode, + final AMQShortString replyText, + final FieldTable details) + { + return new ChannelAlertBody(replyCode, + replyText, + details); + } + + public final ChannelOpenBody createChannelOpenBody(final AMQShortString outOfBand) + { + return new ChannelOpenBody(); + } + + public final ChannelOpenOkBody createChannelOpenOkBody(byte[] channelId) + { + return createChannelOpenOkBody(); + } + + public final ChannelOpenOkBody createChannelOpenOkBody() + { + return _protocolVersion.equals(ProtocolVersion.v8_0) + ? ChannelOpenOkBody.INSTANCE_0_8 + : ChannelOpenOkBody.INSTANCE_0_9; + } + + public final ChannelFlowBody createChannelFlowBody(final boolean active) + { + return new ChannelFlowBody(active); + } + public final ChannelFlowOkBody createChannelFlowOkBody(final boolean active) + { + return new ChannelFlowOkBody(active); + } + + public final ChannelCloseBody createChannelCloseBody(final int replyCode, final AMQShortString replyText, + final int classId, + final int methodId + ) + { + return new ChannelCloseBody(replyCode, + replyText, + classId, + methodId); + } + + public final ChannelCloseOkBody createChannelCloseOkBody() + { + return ChannelCloseOkBody.INSTANCE; + } + + + + + public final ConnectionStartBody createConnectionStartBody(final short versionMajor, + final short versionMinor, + final FieldTable serverProperties, + final byte[] mechanisms, + final byte[] locales) + { + return new ConnectionStartBody(versionMajor, + versionMinor, + serverProperties, + mechanisms, + locales); + } + + public final ConnectionStartOkBody createConnectionStartOkBody(final FieldTable clientProperties, + final AMQShortString mechanism, + final byte[] response, + final AMQShortString locale) + { + return new ConnectionStartOkBody(clientProperties, + mechanism, + response, + locale); + } + + public final ConnectionSecureBody createConnectionSecureBody(final byte[] challenge) + { + return new ConnectionSecureBody(challenge); + } - public static final MethodRegistry registry_0_9 = - new org.apache.qpid.framing.amqp_0_9.MethodRegistry_0_9(); + public final ConnectionSecureOkBody createConnectionSecureOkBody(final byte[] response) + { + return new ConnectionSecureOkBody(response); + } + + public final ConnectionTuneBody createConnectionTuneBody(final int channelMax, + final long frameMax, + final int heartbeat) + { + return new ConnectionTuneBody(channelMax, + frameMax, + heartbeat); + } - public static final MethodRegistry registry_0_91 = - new org.apache.qpid.framing.amqp_0_91.MethodRegistry_0_91(); + public final ConnectionTuneOkBody createConnectionTuneOkBody(final int channelMax, + final long frameMax, + final int heartbeat) + { + return new ConnectionTuneOkBody(channelMax, + frameMax, + heartbeat); + } - public static final MethodRegistry registry_8_0 = - new org.apache.qpid.framing.amqp_8_0.MethodRegistry_8_0(); + public final ConnectionOpenBody createConnectionOpenBody(final AMQShortString virtualHost, + final AMQShortString capabilities, + final boolean insist) + { + return new ConnectionOpenBody(virtualHost, + capabilities, + insist); + } - public abstract AMQMethodBody convertToBody(MarkableDataInput in, long size) - throws AMQFrameDecodingException, IOException; + public final ConnectionOpenOkBody createConnectionOpenOkBody(final AMQShortString knownHosts) + { + return new ConnectionOpenOkBody(knownHosts); + } - public abstract int getMaxClassId(); + public final ConnectionRedirectBody createConnectionRedirectBody(final AMQShortString host, + final AMQShortString knownHosts) + { + return new ConnectionRedirectBody(_protocolVersion, + host, + knownHosts); + } - public abstract int getMaxMethodId(int classId); + public final ConnectionCloseBody createConnectionCloseBody(final int replyCode, + final AMQShortString replyText, + final int classId, + final int methodId) + { + return new ConnectionCloseBody(_protocolVersion, + replyCode, + replyText, + classId, + methodId); + } - protected MethodRegistry(ProtocolVersion pv) + public final ConnectionCloseOkBody createConnectionCloseOkBody() { - _registries.put(pv, this); + return ProtocolVersion.v8_0 == _protocolVersion + ? ConnectionCloseOkBody.CONNECTION_CLOSE_OK_0_8 + : ConnectionCloseOkBody.CONNECTION_CLOSE_OK_0_9; } - public static MethodRegistry getMethodRegistry(ProtocolVersion pv) + + public final ExchangeDeclareBody createExchangeDeclareBody(final int ticket, + final AMQShortString exchange, + final AMQShortString type, + final boolean passive, + final boolean durable, + final boolean autoDelete, + final boolean internal, + final boolean nowait, + final FieldTable arguments) { - return _registries.get(pv); + return new ExchangeDeclareBody(ticket, + exchange, + type, + passive, + durable, + autoDelete, + internal, + nowait, + arguments); } + public final ExchangeDeclareOkBody createExchangeDeclareOkBody() + { + return new ExchangeDeclareOkBody(); + } + public final ExchangeDeleteBody createExchangeDeleteBody(final int ticket, + final AMQShortString exchange, + final boolean ifUnused, + final boolean nowait) + { + return new ExchangeDeleteBody(ticket, + exchange, + ifUnused, + nowait + ); + } + public final ExchangeDeleteOkBody createExchangeDeleteOkBody() + { + return new ExchangeDeleteOkBody(); + } - public abstract BasicAckBody createBasicAckBody( - final long deliveryTag, - final boolean multiple - ); + public final ExchangeBoundBody createExchangeBoundBody(final AMQShortString exchange, + final AMQShortString routingKey, + final AMQShortString queue) + { + return new ExchangeBoundBody(exchange, + routingKey, + queue); + } - public abstract BasicCancelBody createBasicCancelBody( - final AMQShortString consumerTag, - final boolean nowait - ); + public final ExchangeBoundOkBody createExchangeBoundOkBody(final int replyCode, + final AMQShortString replyText) + { + return new ExchangeBoundOkBody(replyCode, + replyText); + } - public abstract BasicCancelOkBody createBasicCancelOkBody( - final AMQShortString consumerTag - ); - public abstract BasicConsumeBody createBasicConsumeBody( - final int ticket, - final AMQShortString queue, - final AMQShortString consumerTag, - final boolean noLocal, - final boolean noAck, - final boolean exclusive, - final boolean nowait, - final FieldTable arguments - ); + public final QueueDeclareBody createQueueDeclareBody(final int ticket, + final AMQShortString queue, + final boolean passive, + final boolean durable, + final boolean exclusive, + final boolean autoDelete, + final boolean nowait, + final FieldTable arguments) + { + return new QueueDeclareBody(ticket, + queue, + passive, + durable, + exclusive, + autoDelete, + nowait, + arguments); + } - public abstract BasicConsumeOkBody createBasicConsumeOkBody( - final AMQShortString consumerTag - ); + public final QueueDeclareOkBody createQueueDeclareOkBody(final AMQShortString queue, + final long messageCount, + final long consumerCount) + { + return new QueueDeclareOkBody(queue, + messageCount, + consumerCount); + } - public abstract BasicDeliverBody createBasicDeliverBody( - final AMQShortString consumerTag, - final long deliveryTag, - final boolean redelivered, - final AMQShortString exchange, - final AMQShortString routingKey - ); + public final QueueBindBody createQueueBindBody(final int ticket, + final AMQShortString queue, + final AMQShortString exchange, + final AMQShortString routingKey, + final boolean nowait, + final FieldTable arguments) + { + return new QueueBindBody(ticket, + queue, + exchange, + routingKey, + nowait, + arguments); + } - public abstract BasicGetBody createBasicGetBody( - final int ticket, - final AMQShortString queue, - final boolean noAck - ); + public final QueueBindOkBody createQueueBindOkBody() + { + return new QueueBindOkBody(); + } - public abstract BasicGetEmptyBody createBasicGetEmptyBody( - final AMQShortString clusterId - ); + public final QueuePurgeBody createQueuePurgeBody(final int ticket, + final AMQShortString queue, + final boolean nowait) + { + return new QueuePurgeBody(ticket, + queue, + nowait); + } - public abstract BasicGetOkBody createBasicGetOkBody( - final long deliveryTag, - final boolean redelivered, - final AMQShortString exchange, - final AMQShortString routingKey, - final long messageCount - ); + public final QueuePurgeOkBody createQueuePurgeOkBody(final long messageCount) + { + return new QueuePurgeOkBody(messageCount); + } - public abstract BasicPublishBody createBasicPublishBody( - final int ticket, - final AMQShortString exchange, - final AMQShortString routingKey, - final boolean mandatory, - final boolean immediate - ); - - public abstract BasicQosBody createBasicQosBody( - final long prefetchSize, - final int prefetchCount, - final boolean global - ); + public final QueueDeleteBody createQueueDeleteBody(final int ticket, + final AMQShortString queue, + final boolean ifUnused, + final boolean ifEmpty, + final boolean nowait) + { + return new QueueDeleteBody(ticket, + queue, + ifUnused, + ifEmpty, + nowait); + } - public abstract BasicQosOkBody createBasicQosOkBody( - ); - - public abstract BasicRecoverBody createBasicRecoverBody( - final boolean requeue - ); - - public abstract BasicRejectBody createBasicRejectBody( - final long deliveryTag, - final boolean requeue - ); - - public abstract BasicReturnBody createBasicReturnBody( - final int replyCode, - final AMQShortString replyText, - final AMQShortString exchange, - final AMQShortString routingKey - ); - - - public abstract ChannelCloseBody createChannelCloseBody( - final int replyCode, - final AMQShortString replyText, - final int classId, - final int methodId - ); - - public abstract ChannelCloseOkBody createChannelCloseOkBody( - ); - - public abstract ChannelFlowBody createChannelFlowBody( - final boolean active - ); - - public abstract ChannelFlowOkBody createChannelFlowOkBody( - final boolean active - ); - - public abstract ChannelOpenBody createChannelOpenBody( - final AMQShortString outOfBand - ); - - - public abstract ConnectionCloseBody createConnectionCloseBody( - final int replyCode, - final AMQShortString replyText, - final int classId, - final int methodId - ); - - public abstract ConnectionCloseOkBody createConnectionCloseOkBody( - ); - - public abstract ConnectionOpenBody createConnectionOpenBody( - final AMQShortString virtualHost, - final AMQShortString capabilities, - final boolean insist - ); - - public abstract ConnectionOpenOkBody createConnectionOpenOkBody( - final AMQShortString knownHosts - ); - - public abstract ConnectionSecureBody createConnectionSecureBody( - final byte[] challenge - ); - - public abstract ConnectionSecureOkBody createConnectionSecureOkBody( - final byte[] response - ); - - public abstract ConnectionStartBody createConnectionStartBody( - final short versionMajor, - final short versionMinor, - final FieldTable serverProperties, - final byte[] mechanisms, - final byte[] locales - ); - - public abstract ConnectionStartOkBody createConnectionStartOkBody( - final FieldTable clientProperties, - final AMQShortString mechanism, - final byte[] response, - final AMQShortString locale - ); - - public abstract ConnectionTuneBody createConnectionTuneBody( - final int channelMax, - final long frameMax, - final int heartbeat - ); - - public abstract ConnectionTuneOkBody createConnectionTuneOkBody( - final int channelMax, - final long frameMax, - final int heartbeat - ); - - - - public abstract ExchangeBoundBody createExchangeBoundBody( - final AMQShortString exchange, - final AMQShortString routingKey, - final AMQShortString queue - ); - - public abstract ExchangeBoundOkBody createExchangeBoundOkBody( - final int replyCode, - final AMQShortString replyText - ); - - public abstract ExchangeDeclareBody createExchangeDeclareBody( - final int ticket, - final AMQShortString exchange, - final AMQShortString type, - final boolean passive, - final boolean durable, - final boolean autoDelete, - final boolean internal, - final boolean nowait, - final FieldTable arguments - ); - - public abstract ExchangeDeclareOkBody createExchangeDeclareOkBody( - ); - - public abstract ExchangeDeleteBody createExchangeDeleteBody( - final int ticket, - final AMQShortString exchange, - final boolean ifUnused, - final boolean nowait - ); - - public abstract ExchangeDeleteOkBody createExchangeDeleteOkBody( - ); - - - - - public abstract QueueBindBody createQueueBindBody( - final int ticket, - final AMQShortString queue, - final AMQShortString exchange, - final AMQShortString routingKey, - final boolean nowait, - final FieldTable arguments - ); - - public abstract QueueBindOkBody createQueueBindOkBody( - ); - - public abstract QueueDeclareBody createQueueDeclareBody( - final int ticket, - final AMQShortString queue, - final boolean passive, - final boolean durable, - final boolean exclusive, - final boolean autoDelete, - final boolean nowait, - final FieldTable arguments - ); - - public abstract QueueDeclareOkBody createQueueDeclareOkBody( - final AMQShortString queue, - final long messageCount, - final long consumerCount - ); - - public abstract QueueDeleteBody createQueueDeleteBody( - final int ticket, - final AMQShortString queue, - final boolean ifUnused, - final boolean ifEmpty, - final boolean nowait - ); - - public abstract QueueDeleteOkBody createQueueDeleteOkBody( - final long messageCount - ); - - public abstract QueuePurgeBody createQueuePurgeBody( - final int ticket, - final AMQShortString queue, - final boolean nowait - ); + public final QueueDeleteOkBody createQueueDeleteOkBody(final long messageCount) + { + return new QueueDeleteOkBody(messageCount); + } - public abstract QueuePurgeOkBody createQueuePurgeOkBody( - final long messageCount - ); + public final QueueUnbindBody createQueueUnbindBody(final int ticket, + final AMQShortString queue, + final AMQShortString exchange, + final AMQShortString routingKey, + final FieldTable arguments) + { + return new QueueUnbindBody(ticket, + queue, + exchange, + routingKey, + arguments); + } + public final QueueUnbindOkBody createQueueUnbindOkBody() + { + return new QueueUnbindOkBody(); + } + public final TxSelectBody createTxSelectBody() + { + return TxSelectBody.INSTANCE; + } + public final TxSelectOkBody createTxSelectOkBody() + { + return TxSelectOkBody.INSTANCE; + } - public abstract TxCommitBody createTxCommitBody( - ); + public final TxCommitBody createTxCommitBody() + { + return TxCommitBody.INSTANCE; + } - public abstract TxCommitOkBody createTxCommitOkBody( - ); + public final TxCommitOkBody createTxCommitOkBody() + { + return TxCommitOkBody.INSTANCE; + } - public abstract TxRollbackBody createTxRollbackBody( - ); + public final TxRollbackBody createTxRollbackBody() + { + return TxRollbackBody.INSTANCE; + } - public abstract TxRollbackOkBody createTxRollbackOkBody( - ); + public final TxRollbackOkBody createTxRollbackOkBody() + { + return TxRollbackOkBody.INSTANCE; + } - public abstract TxSelectBody createTxSelectBody( - ); + public ProtocolVersion getProtocolVersion() + { + return _protocolVersion; + } - public abstract TxSelectOkBody createTxSelectOkBody( - ); - public abstract ProtocolVersionMethodConverter getProtocolVersionMethodConverter(); } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java index 0bb72aa88f..ed1935ca04 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java @@ -20,14 +20,15 @@ */ package org.apache.qpid.framing; -import org.apache.qpid.AMQException; -import org.apache.qpid.codec.MarkableDataInput; - import java.io.DataOutput; import java.io.IOException; import java.io.UnsupportedEncodingException; +import java.nio.charset.StandardCharsets; import java.util.Arrays; +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + public class ProtocolInitiation extends AMQDataBlock implements EncodableAMQDataBlock { @@ -227,7 +228,7 @@ public class ProtocolInitiation extends AMQDataBlock implements EncodableAMQData public String toString() { - StringBuffer buffer = new StringBuffer(new String(_protocolHeader)); + StringBuffer buffer = new StringBuffer(new String(_protocolHeader, StandardCharsets.US_ASCII)); buffer.append(Integer.toHexString(_protocolClass)); buffer.append(Integer.toHexString(_protocolInstance)); buffer.append(Integer.toHexString(_protocolMajor)); diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueBindBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueBindBody.java index d5f3b2b924..2b7e26a7f0 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueBindBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueBindBody.java @@ -22,25 +22,162 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface QueueBindBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class QueueBindBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public FieldTable getArguments(); + public static final int CLASS_ID = 50; + public static final int METHOD_ID = 20; + + // Fields declared in specification + private final int _ticket; // [ticket] + private final AMQShortString _queue; // [queue] + private final AMQShortString _exchange; // [exchange] + private final AMQShortString _routingKey; // [routingKey] + private final byte _bitfield0; // [nowait] + private final FieldTable _arguments; // [arguments] + + // Constructor + public QueueBindBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _ticket = buffer.readUnsignedShort(); + _queue = buffer.readAMQShortString(); + _exchange = buffer.readAMQShortString(); + _routingKey = buffer.readAMQShortString(); + _bitfield0 = buffer.readByte(); + _arguments = EncodingUtils.readFieldTable(buffer); + } + + public QueueBindBody( + int ticket, + AMQShortString queue, + AMQShortString exchange, + AMQShortString routingKey, + boolean nowait, + FieldTable arguments + ) + { + _ticket = ticket; + _queue = queue; + _exchange = exchange; + _routingKey = routingKey; + byte bitfield0 = (byte)0; + if( nowait ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + + _bitfield0 = bitfield0; + _arguments = arguments; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getTicket() + { + return _ticket; + } + public final AMQShortString getQueue() + { + return _queue; + } + public final AMQShortString getExchange() + { + return _exchange; + } + public final AMQShortString getRoutingKey() + { + return _routingKey; + } + public final boolean getNowait() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + public final FieldTable getArguments() + { + return _arguments; + } + + protected int getBodySize() + { + int size = 3; + size += getSizeOf( _queue ); + size += getSizeOf( _exchange ); + size += getSizeOf( _routingKey ); + size += getSizeOf( _arguments ); + return size; + } - public AMQShortString getExchange(); + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _ticket ); + writeAMQShortString( buffer, _queue ); + writeAMQShortString( buffer, _exchange ); + writeAMQShortString( buffer, _routingKey ); + writeBitfield( buffer, _bitfield0 ); + writeFieldTable( buffer, _arguments ); + } - public boolean getNowait(); + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchQueueBind(this, channelId); + } - public AMQShortString getQueue(); + public String toString() + { + StringBuilder buf = new StringBuilder("[QueueBindBodyImpl: "); + buf.append( "ticket=" ); + buf.append( getTicket() ); + buf.append( ", " ); + buf.append( "queue=" ); + buf.append( getQueue() ); + buf.append( ", " ); + buf.append( "exchange=" ); + buf.append( getExchange() ); + buf.append( ", " ); + buf.append( "routingKey=" ); + buf.append( getRoutingKey() ); + buf.append( ", " ); + buf.append( "nowait=" ); + buf.append( getNowait() ); + buf.append( ", " ); + buf.append( "arguments=" ); + buf.append( getArguments() ); + buf.append("]"); + return buf.toString(); + } - public AMQShortString getRoutingKey(); + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) throws IOException, AMQFrameDecodingException + { - public int getTicket(); + int ticket = buffer.readUnsignedShort(); + AMQShortString queue = buffer.readAMQShortString(); + AMQShortString exchange = buffer.readAMQShortString(); + AMQShortString bindingKey = buffer.readAMQShortString(); + boolean nowait = (buffer.readByte() & 0x01) == 0x01; + FieldTable arguments = EncodingUtils.readFieldTable(buffer); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveQueueBind(queue, exchange, bindingKey, nowait, arguments); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueBindOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueBindOkBody.java index 3e2f0104f8..cf6b18b932 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueBindOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueBindOkBody.java @@ -22,13 +22,66 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface QueueBindOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class QueueBindOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + + public static final int CLASS_ID = 50; + public static final int METHOD_ID = 21; + + // Fields declared in specification + + // Constructor + public QueueBindOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + } + + public QueueBindOkBody( + ) + { + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + + protected int getBodySize() + { + int size = 0; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchQueueBindOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[QueueBindOkBodyImpl: "); + buf.append("]"); + return buf.toString(); + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeclareBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeclareBody.java index 23066457e6..5a359dc8df 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeclareBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeclareBody.java @@ -22,29 +22,192 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface QueueDeclareBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class QueueDeclareBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public FieldTable getArguments(); + public static final int CLASS_ID = 50; + public static final int METHOD_ID = 10; + + // Fields declared in specification + private final int _ticket; // [ticket] + private final AMQShortString _queue; // [queue] + private final byte _bitfield0; // [passive, durable, exclusive, autoDelete, nowait] + private final FieldTable _arguments; // [arguments] + + // Constructor + public QueueDeclareBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _ticket = buffer.readUnsignedShort(); + _queue = buffer.readAMQShortString(); + _bitfield0 = buffer.readByte(); + _arguments = EncodingUtils.readFieldTable(buffer); + } + + public QueueDeclareBody( + int ticket, + AMQShortString queue, + boolean passive, + boolean durable, + boolean exclusive, + boolean autoDelete, + boolean nowait, + FieldTable arguments + ) + { + _ticket = ticket; + _queue = queue; + byte bitfield0 = (byte)0; + if( passive ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + + if( durable ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); + } + + if( exclusive ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); + } + + if( autoDelete ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); + } + + if( nowait ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 4)); + } + + _bitfield0 = bitfield0; + _arguments = arguments; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getTicket() + { + return _ticket; + } + public final AMQShortString getQueue() + { + return _queue; + } + public final boolean getPassive() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + public final boolean getDurable() + { + return (((int)(_bitfield0)) & ( 1 << 1)) != 0; + } + public final boolean getExclusive() + { + return (((int)(_bitfield0)) & ( 1 << 2)) != 0; + } + public final boolean getAutoDelete() + { + return (((int)(_bitfield0)) & ( 1 << 3)) != 0; + } + public final boolean getNowait() + { + return (((int)(_bitfield0)) & ( 1 << 4)) != 0; + } + public final FieldTable getArguments() + { + return _arguments; + } - public boolean getAutoDelete(); + protected int getBodySize() + { + int size = 3; + size += getSizeOf( _queue ); + size += getSizeOf( _arguments ); + return size; + } - public boolean getDurable(); + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _ticket ); + writeAMQShortString( buffer, _queue ); + writeBitfield( buffer, _bitfield0 ); + writeFieldTable( buffer, _arguments ); + } - public boolean getExclusive(); + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchQueueDeclare(this, channelId); + } - public boolean getNowait(); + public String toString() + { + StringBuilder buf = new StringBuilder("[QueueDeclareBodyImpl: "); + buf.append( "ticket=" ); + buf.append( getTicket() ); + buf.append( ", " ); + buf.append( "queue=" ); + buf.append( getQueue() ); + buf.append( ", " ); + buf.append( "passive=" ); + buf.append( getPassive() ); + buf.append( ", " ); + buf.append( "durable=" ); + buf.append( getDurable() ); + buf.append( ", " ); + buf.append( "exclusive=" ); + buf.append( getExclusive() ); + buf.append( ", " ); + buf.append( "autoDelete=" ); + buf.append( getAutoDelete() ); + buf.append( ", " ); + buf.append( "nowait=" ); + buf.append( getNowait() ); + buf.append( ", " ); + buf.append( "arguments=" ); + buf.append( getArguments() ); + buf.append("]"); + return buf.toString(); + } - public boolean getPassive(); + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) throws IOException, AMQFrameDecodingException + { - public AMQShortString getQueue(); + int ticket = buffer.readUnsignedShort(); + AMQShortString queue = buffer.readAMQShortString(); + byte bitfield = buffer.readByte(); - public int getTicket(); + boolean passive = (bitfield & 0x01 ) == 0x01; + boolean durable = (bitfield & 0x02 ) == 0x02; + boolean exclusive = (bitfield & 0x04 ) == 0x04; + boolean autoDelete = (bitfield & 0x08 ) == 0x08; + boolean nowait = (bitfield & 0x010 ) == 0x010; + FieldTable arguments = EncodingUtils.readFieldTable(buffer); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveQueueDeclare(queue, passive, durable, exclusive, autoDelete, nowait, arguments); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeclareOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeclareOkBody.java index 0557f2c54d..cf6fc656b3 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeclareOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeclareOkBody.java @@ -22,19 +22,113 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface QueueDeclareOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class QueueDeclareOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public long getConsumerCount(); + public static final int CLASS_ID = 50; + public static final int METHOD_ID = 11; + + // Fields declared in specification + private final AMQShortString _queue; // [queue] + private final long _messageCount; // [messageCount] + private final long _consumerCount; // [consumerCount] + + // Constructor + public QueueDeclareOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _queue = buffer.readAMQShortString(); + _messageCount = EncodingUtils.readUnsignedInteger(buffer); + _consumerCount = EncodingUtils.readUnsignedInteger(buffer); + } + + public QueueDeclareOkBody( + AMQShortString queue, + long messageCount, + long consumerCount + ) + { + _queue = queue; + _messageCount = messageCount; + _consumerCount = consumerCount; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final AMQShortString getQueue() + { + return _queue; + } + public final long getMessageCount() + { + return _messageCount; + } + public final long getConsumerCount() + { + return _consumerCount; + } + + protected int getBodySize() + { + int size = 8; + size += getSizeOf( _queue ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeAMQShortString( buffer, _queue ); + writeUnsignedInteger( buffer, _messageCount ); + writeUnsignedInteger( buffer, _consumerCount ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchQueueDeclareOk(this, channelId); + } - public long getMessageCount(); + public String toString() + { + StringBuilder buf = new StringBuilder("[QueueDeclareOkBodyImpl: "); + buf.append( "queue=" ); + buf.append( getQueue() ); + buf.append( ", " ); + buf.append( "messageCount=" ); + buf.append( getMessageCount() ); + buf.append( ", " ); + buf.append( "consumerCount=" ); + buf.append( getConsumerCount() ); + buf.append("]"); + return buf.toString(); + } - public AMQShortString getQueue(); + public static void process(final MarkableDataInput buffer, + final ClientChannelMethodProcessor dispatcher) throws IOException + { + AMQShortString queue = buffer.readAMQShortString(); + long messageCount = EncodingUtils.readUnsignedInteger(buffer); + long consumerCount = EncodingUtils.readUnsignedInteger(buffer); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveQueueDeclareOk(queue, messageCount, consumerCount); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeleteBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeleteBody.java index 2cced4d67e..ea933dc644 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeleteBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeleteBody.java @@ -22,23 +22,149 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface QueueDeleteBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class QueueDeleteBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public boolean getIfEmpty(); + public static final int CLASS_ID = 50; + public static final int METHOD_ID = 40; + + // Fields declared in specification + private final int _ticket; // [ticket] + private final AMQShortString _queue; // [queue] + private final byte _bitfield0; // [ifUnused, ifEmpty, nowait] + + // Constructor + public QueueDeleteBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _ticket = buffer.readUnsignedShort(); + _queue = buffer.readAMQShortString(); + _bitfield0 = buffer.readByte(); + } + + public QueueDeleteBody( + int ticket, + AMQShortString queue, + boolean ifUnused, + boolean ifEmpty, + boolean nowait + ) + { + _ticket = ticket; + _queue = queue; + byte bitfield0 = (byte)0; + if( ifUnused ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + + if( ifEmpty ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); + } + + if( nowait ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); + } + _bitfield0 = bitfield0; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getTicket() + { + return _ticket; + } + public final AMQShortString getQueue() + { + return _queue; + } + public final boolean getIfUnused() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + public final boolean getIfEmpty() + { + return (((int)(_bitfield0)) & ( 1 << 1)) != 0; + } + public final boolean getNowait() + { + return (((int)(_bitfield0)) & ( 1 << 2)) != 0; + } + + protected int getBodySize() + { + int size = 3; + size += getSizeOf( _queue ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _ticket ); + writeAMQShortString( buffer, _queue ); + writeBitfield( buffer, _bitfield0 ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchQueueDelete(this, channelId); + } - public boolean getIfUnused(); + public String toString() + { + StringBuilder buf = new StringBuilder("[QueueDeleteBodyImpl: "); + buf.append( "ticket=" ); + buf.append( getTicket() ); + buf.append( ", " ); + buf.append( "queue=" ); + buf.append( getQueue() ); + buf.append( ", " ); + buf.append( "ifUnused=" ); + buf.append( getIfUnused() ); + buf.append( ", " ); + buf.append( "ifEmpty=" ); + buf.append( getIfEmpty() ); + buf.append( ", " ); + buf.append( "nowait=" ); + buf.append( getNowait() ); + buf.append("]"); + return buf.toString(); + } - public boolean getNowait(); + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) throws IOException + { - public AMQShortString getQueue(); + int ticket = buffer.readUnsignedShort(); + AMQShortString queue = buffer.readAMQShortString(); + byte bitfield = buffer.readByte(); - public int getTicket(); + boolean ifUnused = (bitfield & 0x01) == 0x01; + boolean ifEmpty = (bitfield & 0x02) == 0x02; + boolean nowait = (bitfield & 0x04) == 0x04; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveQueueDelete(queue, ifUnused, ifEmpty, nowait); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeleteOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeleteOkBody.java index 41acf6f246..6d50153c15 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeleteOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueDeleteOkBody.java @@ -22,15 +22,86 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface QueueDeleteOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class QueueDeleteOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public long getMessageCount(); + public static final int CLASS_ID = 50; + public static final int METHOD_ID = 41; + + // Fields declared in specification + private final long _messageCount; // [messageCount] + + // Constructor + public QueueDeleteOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _messageCount = EncodingUtils.readUnsignedInteger(buffer); + } + + public QueueDeleteOkBody( + long messageCount + ) + { + _messageCount = messageCount; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final long getMessageCount() + { + return _messageCount; + } + + protected int getBodySize() + { + int size = 4; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedInteger( buffer, _messageCount ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchQueueDeleteOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[QueueDeleteOkBodyImpl: "); + buf.append( "messageCount=" ); + buf.append( getMessageCount() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput buffer, + final ClientChannelMethodProcessor dispatcher) throws IOException + { + long messageCount = EncodingUtils.readUnsignedInteger(buffer); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveQueueDeleteOk(messageCount); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueuePurgeBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueuePurgeBody.java index 1965345997..58a424387c 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueuePurgeBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueuePurgeBody.java @@ -22,19 +22,119 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface QueuePurgeBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class QueuePurgeBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public boolean getNowait(); + public static final int CLASS_ID = 50; + public static final int METHOD_ID = 30; + + // Fields declared in specification + private final int _ticket; // [ticket] + private final AMQShortString _queue; // [queue] + private final byte _bitfield0; // [nowait] + + // Constructor + public QueuePurgeBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _ticket = buffer.readUnsignedShort(); + _queue = buffer.readAMQShortString(); + _bitfield0 = buffer.readByte(); + } + + public QueuePurgeBody( + int ticket, + AMQShortString queue, + boolean nowait + ) + { + _ticket = ticket; + _queue = queue; + byte bitfield0 = (byte)0; + if( nowait ) + { + bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); + } + _bitfield0 = bitfield0; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getTicket() + { + return _ticket; + } + public final AMQShortString getQueue() + { + return _queue; + } + public final boolean getNowait() + { + return (((int)(_bitfield0)) & ( 1 << 0)) != 0; + } + + protected int getBodySize() + { + int size = 3; + size += getSizeOf( _queue ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _ticket ); + writeAMQShortString( buffer, _queue ); + writeBitfield( buffer, _bitfield0 ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchQueuePurge(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[QueuePurgeBodyImpl: "); + buf.append( "ticket=" ); + buf.append( getTicket() ); + buf.append( ", " ); + buf.append( "queue=" ); + buf.append( getQueue() ); + buf.append( ", " ); + buf.append( "nowait=" ); + buf.append( getNowait() ); + buf.append("]"); + return buf.toString(); + } - public AMQShortString getQueue(); + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) throws IOException + { - public int getTicket(); + int ticket = buffer.readUnsignedShort(); + AMQShortString queue = buffer.readAMQShortString(); + boolean nowait = (buffer.readByte() & 0x01) == 0x01; + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveQueuePurge(queue, nowait); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueuePurgeOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueuePurgeOkBody.java index 2641dcf81d..acab2bc052 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueuePurgeOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueuePurgeOkBody.java @@ -22,15 +22,86 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface QueuePurgeOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class QueuePurgeOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public long getMessageCount(); + public static final int CLASS_ID = 50; + public static final int METHOD_ID = 31; + + // Fields declared in specification + private final long _messageCount; // [messageCount] + + // Constructor + public QueuePurgeOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _messageCount = EncodingUtils.readUnsignedInteger(buffer); + } + + public QueuePurgeOkBody( + long messageCount + ) + { + _messageCount = messageCount; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final long getMessageCount() + { + return _messageCount; + } + + protected int getBodySize() + { + int size = 4; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedInteger( buffer, _messageCount ); + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchQueuePurgeOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[QueuePurgeOkBodyImpl: "); + buf.append( "messageCount=" ); + buf.append( getMessageCount() ); + buf.append("]"); + return buf.toString(); + } + + public static void process(final MarkableDataInput buffer, + final ClientChannelMethodProcessor dispatcher) throws IOException + { + long messageCount = EncodingUtils.readUnsignedInteger(buffer); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveQueuePurgeOk(messageCount); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueUnbindBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueUnbindBody.java index 9c6caafc74..30c5d19d27 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueUnbindBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueUnbindBody.java @@ -22,23 +22,143 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 0-91 + */ package org.apache.qpid.framing; -public interface QueueUnbindBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class QueueUnbindBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { - public FieldTable getArguments(); + public static final int CLASS_ID = 50; + public static final int METHOD_ID = 50; + + // Fields declared in specification + private final int _ticket; // [ticket] + private final AMQShortString _queue; // [queue] + private final AMQShortString _exchange; // [exchange] + private final AMQShortString _routingKey; // [routingKey] + private final FieldTable _arguments; // [arguments] + + // Constructor + public QueueUnbindBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + _ticket = buffer.readUnsignedShort(); + _queue = buffer.readAMQShortString(); + _exchange = buffer.readAMQShortString(); + _routingKey = buffer.readAMQShortString(); + _arguments = EncodingUtils.readFieldTable(buffer); + } + + public QueueUnbindBody( + int ticket, + AMQShortString queue, + AMQShortString exchange, + AMQShortString routingKey, + FieldTable arguments + ) + { + _ticket = ticket; + _queue = queue; + _exchange = exchange; + _routingKey = routingKey; + _arguments = arguments; + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + public final int getTicket() + { + return _ticket; + } + public final AMQShortString getQueue() + { + return _queue; + } + public final AMQShortString getExchange() + { + return _exchange; + } + public final AMQShortString getRoutingKey() + { + return _routingKey; + } + public final FieldTable getArguments() + { + return _arguments; + } + + protected int getBodySize() + { + int size = 2; + size += getSizeOf( _queue ); + size += getSizeOf( _exchange ); + size += getSizeOf( _routingKey ); + size += getSizeOf( _arguments ); + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + writeUnsignedShort( buffer, _ticket ); + writeAMQShortString( buffer, _queue ); + writeAMQShortString( buffer, _exchange ); + writeAMQShortString( buffer, _routingKey ); + writeFieldTable( buffer, _arguments ); + } - public AMQShortString getExchange(); + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchQueueUnbind(this, channelId); + } - public AMQShortString getQueue(); + public String toString() + { + StringBuilder buf = new StringBuilder("[QueueUnbindBodyImpl: "); + buf.append( "ticket=" ); + buf.append( getTicket() ); + buf.append( ", " ); + buf.append( "queue=" ); + buf.append( getQueue() ); + buf.append( ", " ); + buf.append( "exchange=" ); + buf.append( getExchange() ); + buf.append( ", " ); + buf.append( "routingKey=" ); + buf.append( getRoutingKey() ); + buf.append( ", " ); + buf.append( "arguments=" ); + buf.append( getArguments() ); + buf.append("]"); + return buf.toString(); + } - public AMQShortString getRoutingKey(); + public static void process(final MarkableDataInput buffer, + final ServerChannelMethodProcessor dispatcher) throws IOException, AMQFrameDecodingException + { - public int getTicket(); + int ticket = buffer.readUnsignedShort(); + AMQShortString queue = buffer.readAMQShortString(); + AMQShortString exchange = buffer.readAMQShortString(); + AMQShortString routingKey = buffer.readAMQShortString(); + FieldTable arguments = EncodingUtils.readFieldTable(buffer); + if(!dispatcher.ignoreAllButCloseOk()) + { + dispatcher.receiveQueueUnbind(queue, exchange, routingKey, arguments); + } + } } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueUnbindOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueUnbindOkBody.java index bdd8eb9359..2e504d6fc7 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueUnbindOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/QueueUnbindOkBody.java @@ -22,13 +22,66 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 0-91 + */ package org.apache.qpid.framing; -public interface QueueUnbindOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; +import org.apache.qpid.codec.MarkableDataInput; + +public class QueueUnbindOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + + public static final int CLASS_ID = 50; + public static final int METHOD_ID = 51; + + // Fields declared in specification + + // Constructor + public QueueUnbindOkBody(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException + { + } + + public QueueUnbindOkBody( + ) + { + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + + protected int getBodySize() + { + int size = 0; + return size; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchQueueUnbindOk(this, channelId); + } + + public String toString() + { + StringBuilder buf = new StringBuilder("[QueueUnbindOkBodyImpl: "); + buf.append("]"); + return buf.toString(); + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ServerChannelMethodProcessor.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ServerChannelMethodProcessor.java new file mode 100644 index 0000000000..89b75c2d2f --- /dev/null +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ServerChannelMethodProcessor.java @@ -0,0 +1,92 @@ +/* + * + * 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.framing; + +public interface ServerChannelMethodProcessor extends ChannelMethodProcessor +{ + void receiveAccessRequest(AMQShortString realm, + boolean exclusive, + boolean passive, + boolean active, + boolean write, boolean read); + + void receiveExchangeDeclare(AMQShortString exchange, + AMQShortString type, + boolean passive, + boolean durable, + boolean autoDelete, boolean internal, boolean nowait, final FieldTable arguments); + + void receiveExchangeDelete(AMQShortString exchange, boolean ifUnused, boolean nowait); + + void receiveExchangeBound(AMQShortString exchange, AMQShortString routingKey, AMQShortString queue); + + void receiveQueueDeclare(AMQShortString queue, + boolean passive, + boolean durable, + boolean exclusive, + boolean autoDelete, boolean nowait, FieldTable arguments); + + void receiveQueueBind(AMQShortString queue, + AMQShortString exchange, + AMQShortString bindingKey, + boolean nowait, FieldTable arguments); + + void receiveQueuePurge(AMQShortString queue, boolean nowait); + + void receiveQueueDelete(AMQShortString queue, boolean ifUnused, boolean ifEmpty, boolean nowait); + + void receiveQueueUnbind(AMQShortString queue, + AMQShortString exchange, + AMQShortString bindingKey, + FieldTable arguments); + + void receiveBasicRecover(final boolean requeue, boolean sync); + + void receiveBasicQos(long prefetchSize, int prefetchCount, boolean global); + + void receiveBasicConsume(AMQShortString queue, + AMQShortString consumerTag, + boolean noLocal, + boolean noAck, + boolean exclusive, boolean nowait, FieldTable arguments); + + void receiveBasicCancel(AMQShortString consumerTag, boolean noWait); + + void receiveBasicPublish(AMQShortString exchange, + AMQShortString routingKey, + boolean mandatory, + boolean immediate); + + void receiveBasicGet(AMQShortString queue, boolean noAck); + + void receiveBasicAck(long deliveryTag, boolean multiple); + + void receiveBasicReject(long deliveryTag, boolean requeue); + + + + void receiveTxSelect(); + + void receiveTxCommit(); + + void receiveTxRollback(); + +} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/ServerMethodDispatcher.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ServerMethodDispatcher.java index 6df8defed1..f4ab67dad4 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/ServerMethodDispatcher.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ServerMethodDispatcher.java @@ -33,6 +33,7 @@ import org.apache.qpid.AMQException; public interface ServerMethodDispatcher { + boolean dispatchAccessRequest(AccessRequestBody accessRequestBody, int channelId) throws AMQException; public boolean dispatchBasicAck(BasicAckBody body, int channelId) throws AMQException; public boolean dispatchBasicCancel(BasicCancelBody body, int channelId) throws AMQException; @@ -64,4 +65,7 @@ public interface ServerMethodDispatcher public boolean dispatchTxRollback(TxRollbackBody body, int channelId) throws AMQException; public boolean dispatchTxSelect(TxSelectBody body, int channelId) throws AMQException; -}
\ No newline at end of file + boolean dispatchQueueUnbind(QueueUnbindBody queueUnbindBody, int channelId) throws AMQException; + + boolean dispatchBasicRecoverSync(BasicRecoverSyncBody basicRecoverSyncBody, int channelId) throws AMQException; +} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileConsumeBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/ServerMethodProcessor.java index 632bc1cf85..77b4a1fc6b 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/FileConsumeBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/ServerMethodProcessor.java @@ -18,32 +18,22 @@ * under the License. * */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - package org.apache.qpid.framing; -public interface FileConsumeBody extends EncodableAMQDataBlock, AMQMethodBody +public interface ServerMethodProcessor<T extends ServerChannelMethodProcessor> extends MethodProcessor<T> { + void receiveConnectionStartOk(FieldTable clientProperties, + AMQShortString mechanism, + byte[] response, + AMQShortString locale); - public AMQShortString getConsumerTag(); - - public boolean getExclusive(); - + void receiveConnectionSecureOk(byte[] response); - public boolean getNoAck(); + void receiveConnectionTuneOk(int channelMax, long frameMax, int heartbeat); - public boolean getNoLocal(); + void receiveConnectionOpen(AMQShortString virtualHost, AMQShortString capabilities, boolean insist); - public boolean getNowait(); + void receiveChannelOpen(int channelId); - public AMQShortString getQueue(); - public int getTicket(); } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamCancelBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamCancelBody.java deleted file mode 100644 index f5325ae4c0..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamCancelBody.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface StreamCancelBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getConsumerTag(); - - public boolean getNowait(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamCancelOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamCancelOkBody.java deleted file mode 100644 index f19410d97f..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamCancelOkBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface StreamCancelOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getConsumerTag(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamConsumeOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamConsumeOkBody.java deleted file mode 100644 index 3d089823e2..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamConsumeOkBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface StreamConsumeOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getConsumerTag(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamDeliverBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamDeliverBody.java deleted file mode 100644 index 76a6231ad6..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamDeliverBody.java +++ /dev/null @@ -1,42 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface StreamDeliverBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getConsumerTag(); - - public long getDeliveryTag(); - - public AMQShortString getExchange(); - - public AMQShortString getQueue(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamPublishBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamPublishBody.java deleted file mode 100644 index 98860389bc..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamPublishBody.java +++ /dev/null @@ -1,44 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface StreamPublishBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getExchange(); - - public boolean getImmediate(); - - public boolean getMandatory(); - - public AMQShortString getRoutingKey(); - - public int getTicket(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamQosBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamQosBody.java deleted file mode 100644 index e28c4abd59..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamQosBody.java +++ /dev/null @@ -1,42 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface StreamQosBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public long getConsumeRate(); - - public boolean getGlobal(); - - public int getPrefetchCount(); - - public long getPrefetchSize(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamQosOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamQosOkBody.java deleted file mode 100644 index 1a71ba1dfa..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamQosOkBody.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface StreamQosOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamReturnBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamReturnBody.java deleted file mode 100644 index e87863080d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/StreamReturnBody.java +++ /dev/null @@ -1,42 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface StreamReturnBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public AMQShortString getExchange(); - - public int getReplyCode(); - - public AMQShortString getReplyText(); - - public AMQShortString getRoutingKey(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestContentBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TestContentBody.java deleted file mode 100644 index 96b5a056c5..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestContentBody.java +++ /dev/null @@ -1,34 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface TestContentBody extends EncodableAMQDataBlock, AMQMethodBody -{ -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestContentOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TestContentOkBody.java deleted file mode 100644 index 9da514a20b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestContentOkBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface TestContentOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public long getContentChecksum(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestIntegerBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TestIntegerBody.java deleted file mode 100644 index a024aba9c6..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestIntegerBody.java +++ /dev/null @@ -1,44 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface TestIntegerBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public short getInteger1(); - - public int getInteger2(); - - public long getInteger3(); - - public long getInteger4(); - - public short getOperation(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestIntegerOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TestIntegerOkBody.java deleted file mode 100644 index 7f7003031c..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestIntegerOkBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface TestIntegerOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public long getResult(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestStringBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TestStringBody.java deleted file mode 100644 index 9474521aad..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestStringBody.java +++ /dev/null @@ -1,40 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface TestStringBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public short getOperation(); - - public AMQShortString getString1(); - - public byte[] getString2(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestStringOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TestStringOkBody.java deleted file mode 100644 index 7dc519a92e..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestStringOkBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface TestStringOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public byte[] getResult(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestTableBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TestTableBody.java deleted file mode 100644 index 4b80b72771..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestTableBody.java +++ /dev/null @@ -1,40 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface TestTableBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public short getIntegerOp(); - - public short getStringOp(); - - public FieldTable getTable(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestTableOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TestTableOkBody.java deleted file mode 100644 index af3f3ca864..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TestTableOkBody.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface TestTableOkBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public long getIntegerResult(); - - public byte[] getStringResult(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TunnelRequestBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TunnelRequestBody.java deleted file mode 100644 index 98785aa4cc..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TunnelRequestBody.java +++ /dev/null @@ -1,36 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ - -package org.apache.qpid.framing; - -public interface TunnelRequestBody extends EncodableAMQDataBlock, AMQMethodBody -{ - - public FieldTable getMetaData(); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TxCommitBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TxCommitBody.java index 189ea0cd40..63c12dffc6 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TxCommitBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/TxCommitBody.java @@ -22,13 +22,59 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface TxCommitBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; + +public class TxCommitBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + + public static final int CLASS_ID = 90; + public static final int METHOD_ID = 20; + + public static final TxCommitBody INSTANCE = new TxCommitBody(); + + // Constructor + + + public TxCommitBody() + { + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + + protected int getBodySize() + { + return 0; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchTxCommit(this, channelId); + } + + public String toString() + { + return "[TxCommitBody]"; + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TxCommitOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TxCommitOkBody.java index 3df65e0504..c1a8dd0d23 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TxCommitOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/TxCommitOkBody.java @@ -22,13 +22,57 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface TxCommitOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; + +public class TxCommitOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + + public static final int CLASS_ID = 90; + public static final int METHOD_ID = 21; + + public static final TxCommitOkBody INSTANCE = new TxCommitOkBody(); + + // Constructor + private TxCommitOkBody() + { + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + + protected int getBodySize() + { + return 0; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchTxCommitOk(this, channelId); + } + + public String toString() + { + return "[TxCommitOkBody]"; + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TxRollbackBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TxRollbackBody.java index d440dc8e04..97ac5ddcba 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TxRollbackBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/TxRollbackBody.java @@ -22,13 +22,57 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface TxRollbackBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; + +public class TxRollbackBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + + public static final int CLASS_ID = 90; + public static final int METHOD_ID = 30; + + public static final TxRollbackBody INSTANCE = new TxRollbackBody(); + + + private TxRollbackBody() + { + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + + protected int getBodySize() + { + return 0; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchTxRollback(this, channelId); + } + + public String toString() + { + return "[TxRollbackBody]"; + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TxRollbackOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TxRollbackOkBody.java index c542ff790a..d8ab92c1c3 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TxRollbackOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/TxRollbackOkBody.java @@ -22,13 +22,58 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface TxRollbackOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; + +public class TxRollbackOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + + public static final int CLASS_ID = 90; + public static final int METHOD_ID = 31; + + public static final TxRollbackOkBody INSTANCE = new TxRollbackOkBody(); + + // Constructor + + private TxRollbackOkBody() + { + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + + protected int getBodySize() + { + return 0; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchTxRollbackOk(this, channelId); + } + + public String toString() + { + return "[TxRollbackOkBody]"; + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TxSelectBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TxSelectBody.java index c3c881cd9d..79af85f177 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TxSelectBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/TxSelectBody.java @@ -22,13 +22,60 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface TxSelectBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; + +public class TxSelectBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + + public static final int CLASS_ID = 90; + public static final int METHOD_ID = 10; + + public static final TxSelectBody INSTANCE = new TxSelectBody(); + + // Fields declared in specification + + // Constructor + + private TxSelectBody() + { + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + + protected int getBodySize() + { + return 0; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchTxSelect(this, channelId); + } + + public String toString() + { + return "[TxSelectBody]"; + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/TxSelectOkBody.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/TxSelectOkBody.java index 6841283bb2..64c8979deb 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/TxSelectOkBody.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/framing/TxSelectOkBody.java @@ -22,13 +22,56 @@ /* * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. * Supported AMQP version: - * 0-9 - * 0-91 - * 8-0 - */ + * 8-0 + */ package org.apache.qpid.framing; -public interface TxSelectOkBody extends EncodableAMQDataBlock, AMQMethodBody +import java.io.DataOutput; +import java.io.IOException; + +import org.apache.qpid.AMQException; + +public class TxSelectOkBody extends AMQMethodBodyImpl implements EncodableAMQDataBlock, AMQMethodBody { + + public static final int CLASS_ID = 90; + public static final int METHOD_ID = 11; + + public static final TxSelectOkBody INSTANCE = new TxSelectOkBody(); + + private TxSelectOkBody() + { + } + + public int getClazz() + { + return CLASS_ID; + } + + public int getMethod() + { + return METHOD_ID; + } + + + protected int getBodySize() + { + return 0; + } + + public void writeMethodPayload(DataOutput buffer) throws IOException + { + } + + public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException + { + return dispatcher.dispatchTxSelectOk(this, channelId); + } + + public String toString() + { + return "[TxSelectOkBody]"; + } + } diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/abstraction/AbstractMethodConverter.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/abstraction/AbstractMethodConverter.java deleted file mode 100644 index 1d7c05e9cc..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/abstraction/AbstractMethodConverter.java +++ /dev/null @@ -1,47 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -package org.apache.qpid.framing.abstraction; - -public abstract class AbstractMethodConverter implements ProtocolVersionMethodConverter -{ - private final byte _protocolMajorVersion; - - - private final byte _protocolMinorVersion; - - public AbstractMethodConverter(byte major, byte minor) - { - _protocolMajorVersion = major; - _protocolMinorVersion = minor; - } - - - public final byte getProtocolMajorVersion() - { - return _protocolMajorVersion; - } - - public final byte getProtocolMinorVersion() - { - return _protocolMinorVersion; - } -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/abstraction/MessagePublishInfo.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/abstraction/MessagePublishInfo.java deleted file mode 100644 index a96bdcc171..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/abstraction/MessagePublishInfo.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ -package org.apache.qpid.framing.abstraction; - -import org.apache.qpid.framing.AMQShortString; - -public interface MessagePublishInfo -{ - - public AMQShortString getExchange(); - - public void setExchange(AMQShortString exchange); - - public boolean isImmediate(); - - public boolean isMandatory(); - - public AMQShortString getRoutingKey(); - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/abstraction/ProtocolVersionMethodConverter.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/abstraction/ProtocolVersionMethodConverter.java deleted file mode 100644 index b3897771c5..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/abstraction/ProtocolVersionMethodConverter.java +++ /dev/null @@ -1,30 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -package org.apache.qpid.framing.abstraction; - -import org.apache.qpid.framing.AMQMethodBody; - -public interface ProtocolVersionMethodConverter -{ - public MessagePublishInfo convertToInfo(AMQMethodBody body); - public AMQMethodBody convertToBody(MessagePublishInfo info); -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/AMQMethodBody_0_9.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/AMQMethodBody_0_9.java deleted file mode 100644 index 8d51343507..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/AMQMethodBody_0_9.java +++ /dev/null @@ -1,37 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -package org.apache.qpid.framing.amqp_0_9; - -public abstract class AMQMethodBody_0_9 extends org.apache.qpid.framing.AMQMethodBodyImpl -{ - - public byte getMajor() - { - return 0; - } - - public byte getMinor() - { - return 9; - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/AccessRequestBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/AccessRequestBodyImpl.java deleted file mode 100644 index 88897e0ff6..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/AccessRequestBodyImpl.java +++ /dev/null @@ -1,181 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class AccessRequestBodyImpl extends AMQMethodBody_0_9 implements AccessRequestBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new AccessRequestBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 30; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final AMQShortString _realm; // [realm] - private final byte _bitfield0; // [exclusive, passive, active, write, read] - - // Constructor - public AccessRequestBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _realm = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public AccessRequestBodyImpl( - AMQShortString realm, - boolean exclusive, - boolean passive, - boolean active, - boolean write, - boolean read - ) - { - _realm = realm; - byte bitfield0 = (byte)0; - if( exclusive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( passive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( active ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - if( write ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); - } - - if( read ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 4)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getRealm() - { - return _realm; - } - public final boolean getExclusive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getPassive() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getActive() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final boolean getWrite() - { - return (((int)(_bitfield0)) & ( 1 << 3)) != 0; - } - public final boolean getRead() - { - return (((int)(_bitfield0)) & ( 1 << 4)) != 0; - } - - protected int getBodySize() - { - int size = 1; - size += getSizeOf( _realm ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _realm ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchAccessRequest(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[AccessRequestBodyImpl: "); - buf.append( "realm=" ); - buf.append( getRealm() ); - buf.append( ", " ); - buf.append( "exclusive=" ); - buf.append( getExclusive() ); - buf.append( ", " ); - buf.append( "passive=" ); - buf.append( getPassive() ); - buf.append( ", " ); - buf.append( "active=" ); - buf.append( getActive() ); - buf.append( ", " ); - buf.append( "write=" ); - buf.append( getWrite() ); - buf.append( ", " ); - buf.append( "read=" ); - buf.append( getRead() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/AccessRequestOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/AccessRequestOkBodyImpl.java deleted file mode 100644 index 95087228f2..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/AccessRequestOkBodyImpl.java +++ /dev/null @@ -1,111 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class AccessRequestOkBodyImpl extends AMQMethodBody_0_9 implements AccessRequestOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new AccessRequestOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 30; - public static final int METHOD_ID = 11; - - // Fields declared in specification - private final int _ticket; // [ticket] - - // Constructor - public AccessRequestOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - } - - public AccessRequestOkBodyImpl( - int ticket - ) - { - _ticket = ticket; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - - protected int getBodySize() - { - int size = 2; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchAccessRequestOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[AccessRequestOkBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicAckBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicAckBodyImpl.java deleted file mode 100644 index b1f9757391..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicAckBodyImpl.java +++ /dev/null @@ -1,128 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicAckBodyImpl extends AMQMethodBody_0_9 implements BasicAckBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicAckBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 80; - - // Fields declared in specification - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [multiple] - - // Constructor - public BasicAckBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicAckBodyImpl( - long deliveryTag, - boolean multiple - ) - { - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( multiple ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getMultiple() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 9; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicAck(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicAckBodyImpl: "); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "multiple=" ); - buf.append( getMultiple() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicCancelBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicCancelBodyImpl.java deleted file mode 100644 index f536b9d8a5..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicCancelBodyImpl.java +++ /dev/null @@ -1,129 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicCancelBodyImpl extends AMQMethodBody_0_9 implements BasicCancelBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicCancelBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [nowait] - - // Constructor - public BasicCancelBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicCancelBodyImpl( - AMQShortString consumerTag, - boolean nowait - ) - { - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicCancel(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicCancelBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicCancelOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicCancelOkBodyImpl.java deleted file mode 100644 index ae2fe58ff9..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicCancelOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicCancelOkBodyImpl extends AMQMethodBody_0_9 implements BasicCancelOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicCancelOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public BasicCancelOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public BasicCancelOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicCancelOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicCancelOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicConsumeBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicConsumeBodyImpl.java deleted file mode 100644 index 177dc6ace2..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicConsumeBodyImpl.java +++ /dev/null @@ -1,207 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicConsumeBodyImpl extends AMQMethodBody_0_9 implements BasicConsumeBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicConsumeBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [noLocal, noAck, exclusive, nowait] - private final FieldTable _arguments; // [arguments] - - // Constructor - public BasicConsumeBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _arguments = readFieldTable( buffer ); - } - - public BasicConsumeBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString consumerTag, - boolean noLocal, - boolean noAck, - boolean exclusive, - boolean nowait, - FieldTable arguments - ) - { - _ticket = ticket; - _queue = queue; - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( noLocal ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( noAck ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( exclusive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); - } - - _bitfield0 = bitfield0; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNoLocal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getNoAck() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getExclusive() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 3)) != 0; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _consumerTag ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicConsume(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicConsumeBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "noLocal=" ); - buf.append( getNoLocal() ); - buf.append( ", " ); - buf.append( "noAck=" ); - buf.append( getNoAck() ); - buf.append( ", " ); - buf.append( "exclusive=" ); - buf.append( getExclusive() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicConsumeOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicConsumeOkBodyImpl.java deleted file mode 100644 index 647c58cbc4..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicConsumeOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicConsumeOkBodyImpl extends AMQMethodBody_0_9 implements BasicConsumeOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicConsumeOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public BasicConsumeOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public BasicConsumeOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicConsumeOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicConsumeOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicDeliverBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicDeliverBodyImpl.java deleted file mode 100644 index 3d2602e605..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicDeliverBodyImpl.java +++ /dev/null @@ -1,168 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicDeliverBodyImpl extends AMQMethodBody_0_9 implements BasicDeliverBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicDeliverBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 60; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [redelivered] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - - // Constructor - public BasicDeliverBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - } - - public BasicDeliverBodyImpl( - AMQShortString consumerTag, - long deliveryTag, - boolean redelivered, - AMQShortString exchange, - AMQShortString routingKey - ) - { - _consumerTag = consumerTag; - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( redelivered ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - _bitfield0 = bitfield0; - _exchange = exchange; - _routingKey = routingKey; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getRedelivered() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - - protected int getBodySize() - { - int size = 9; - size += getSizeOf( _consumerTag ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicDeliver(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicDeliverBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "redelivered=" ); - buf.append( getRedelivered() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicGetBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicGetBodyImpl.java deleted file mode 100644 index 0b21ddf8e9..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicGetBodyImpl.java +++ /dev/null @@ -1,141 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicGetBodyImpl extends AMQMethodBody_0_9 implements BasicGetBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicGetBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 70; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final byte _bitfield0; // [noAck] - - // Constructor - public BasicGetBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicGetBodyImpl( - int ticket, - AMQShortString queue, - boolean noAck - ) - { - _ticket = ticket; - _queue = queue; - byte bitfield0 = (byte)0; - if( noAck ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final boolean getNoAck() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicGet(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicGetBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "noAck=" ); - buf.append( getNoAck() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicGetEmptyBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicGetEmptyBodyImpl.java deleted file mode 100644 index 29cf72d053..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicGetEmptyBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicGetEmptyBodyImpl extends AMQMethodBody_0_9 implements BasicGetEmptyBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicGetEmptyBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 72; - - // Fields declared in specification - private final AMQShortString _clusterId; // [clusterId] - - // Constructor - public BasicGetEmptyBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _clusterId = readAMQShortString( buffer ); - } - - public BasicGetEmptyBodyImpl( - AMQShortString clusterId - ) - { - _clusterId = clusterId; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getClusterId() - { - return _clusterId; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _clusterId ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _clusterId ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicGetEmpty(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicGetEmptyBodyImpl: "); - buf.append( "clusterId=" ); - buf.append( getClusterId() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicGetOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicGetOkBodyImpl.java deleted file mode 100644 index 00bbdd7082..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicGetOkBodyImpl.java +++ /dev/null @@ -1,167 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicGetOkBodyImpl extends AMQMethodBody_0_9 implements BasicGetOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicGetOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 71; - - // Fields declared in specification - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [redelivered] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final long _messageCount; // [messageCount] - - // Constructor - public BasicGetOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _messageCount = readUnsignedInteger( buffer ); - } - - public BasicGetOkBodyImpl( - long deliveryTag, - boolean redelivered, - AMQShortString exchange, - AMQShortString routingKey, - long messageCount - ) - { - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( redelivered ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - _bitfield0 = bitfield0; - _exchange = exchange; - _routingKey = routingKey; - _messageCount = messageCount; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getRedelivered() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final long getMessageCount() - { - return _messageCount; - } - - protected int getBodySize() - { - int size = 13; - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeUnsignedInteger( buffer, _messageCount ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicGetOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicGetOkBodyImpl: "); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "redelivered=" ); - buf.append( getRedelivered() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "messageCount=" ); - buf.append( getMessageCount() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicPublishBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicPublishBodyImpl.java deleted file mode 100644 index b9f941b85e..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicPublishBodyImpl.java +++ /dev/null @@ -1,167 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicPublishBodyImpl extends AMQMethodBody_0_9 implements BasicPublishBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicPublishBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final byte _bitfield0; // [mandatory, immediate] - - // Constructor - public BasicPublishBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicPublishBodyImpl( - int ticket, - AMQShortString exchange, - AMQShortString routingKey, - boolean mandatory, - boolean immediate - ) - { - _ticket = ticket; - _exchange = exchange; - _routingKey = routingKey; - byte bitfield0 = (byte)0; - if( mandatory ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( immediate ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final boolean getMandatory() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getImmediate() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicPublish(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicPublishBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "mandatory=" ); - buf.append( getMandatory() ); - buf.append( ", " ); - buf.append( "immediate=" ); - buf.append( getImmediate() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicQosBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicQosBodyImpl.java deleted file mode 100644 index c461f6b118..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicQosBodyImpl.java +++ /dev/null @@ -1,140 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicQosBodyImpl extends AMQMethodBody_0_9 implements BasicQosBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicQosBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final long _prefetchSize; // [prefetchSize] - private final int _prefetchCount; // [prefetchCount] - private final byte _bitfield0; // [global] - - // Constructor - public BasicQosBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _prefetchSize = readUnsignedInteger( buffer ); - _prefetchCount = readUnsignedShort( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicQosBodyImpl( - long prefetchSize, - int prefetchCount, - boolean global - ) - { - _prefetchSize = prefetchSize; - _prefetchCount = prefetchCount; - byte bitfield0 = (byte)0; - if( global ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getPrefetchSize() - { - return _prefetchSize; - } - public final int getPrefetchCount() - { - return _prefetchCount; - } - public final boolean getGlobal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 7; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _prefetchSize ); - writeUnsignedShort( buffer, _prefetchCount ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicQos(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicQosBodyImpl: "); - buf.append( "prefetchSize=" ); - buf.append( getPrefetchSize() ); - buf.append( ", " ); - buf.append( "prefetchCount=" ); - buf.append( getPrefetchCount() ); - buf.append( ", " ); - buf.append( "global=" ); - buf.append( getGlobal() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicQosOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicQosOkBodyImpl.java deleted file mode 100644 index 9bc5d6f3b8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicQosOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicQosOkBodyImpl extends AMQMethodBody_0_9 implements BasicQosOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicQosOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public BasicQosOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public BasicQosOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicQosOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicQosOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicRecoverBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicRecoverBodyImpl.java deleted file mode 100644 index 498e8f85dc..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicRecoverBodyImpl.java +++ /dev/null @@ -1,116 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicRecoverBodyImpl extends AMQMethodBody_0_9 implements BasicRecoverBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicRecoverBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 100; - - // Fields declared in specification - private final byte _bitfield0; // [requeue] - - // Constructor - public BasicRecoverBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _bitfield0 = readBitfield( buffer ); - } - - public BasicRecoverBodyImpl( - boolean requeue - ) - { - byte bitfield0 = (byte)0; - if( requeue ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final boolean getRequeue() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicRecover(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicRecoverBodyImpl: "); - buf.append( "requeue=" ); - buf.append( getRequeue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicRecoverSyncBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicRecoverSyncBodyImpl.java deleted file mode 100644 index 05390ea493..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicRecoverSyncBodyImpl.java +++ /dev/null @@ -1,116 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicRecoverSyncBodyImpl extends AMQMethodBody_0_9 implements BasicRecoverSyncBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicRecoverSyncBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 102; - - // Fields declared in specification - private final byte _bitfield0; // [requeue] - - // Constructor - public BasicRecoverSyncBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _bitfield0 = readBitfield( buffer ); - } - - public BasicRecoverSyncBodyImpl( - boolean requeue - ) - { - byte bitfield0 = (byte)0; - if( requeue ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final boolean getRequeue() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicRecoverSync(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicRecoverSyncBodyImpl: "); - buf.append( "requeue=" ); - buf.append( getRequeue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicRecoverSyncOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicRecoverSyncOkBodyImpl.java deleted file mode 100644 index 0b889e4a21..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicRecoverSyncOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicRecoverSyncOkBodyImpl extends AMQMethodBody_0_9 implements BasicRecoverSyncOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicRecoverSyncOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 101; - - // Fields declared in specification - - // Constructor - public BasicRecoverSyncOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public BasicRecoverSyncOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicRecoverSyncOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicRecoverSyncOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicRejectBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicRejectBodyImpl.java deleted file mode 100644 index 3e8cf6b825..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicRejectBodyImpl.java +++ /dev/null @@ -1,128 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicRejectBodyImpl extends AMQMethodBody_0_9 implements BasicRejectBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicRejectBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 90; - - // Fields declared in specification - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [requeue] - - // Constructor - public BasicRejectBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicRejectBodyImpl( - long deliveryTag, - boolean requeue - ) - { - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( requeue ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getRequeue() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 9; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicReject(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicRejectBodyImpl: "); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "requeue=" ); - buf.append( getRequeue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicReturnBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicReturnBodyImpl.java deleted file mode 100644 index c88391dca3..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/BasicReturnBodyImpl.java +++ /dev/null @@ -1,150 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicReturnBodyImpl extends AMQMethodBody_0_9 implements BasicReturnBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicReturnBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 50; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - - // Constructor - public BasicReturnBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - } - - public BasicReturnBodyImpl( - int replyCode, - AMQShortString replyText, - AMQShortString exchange, - AMQShortString routingKey - ) - { - _replyCode = replyCode; - _replyText = replyText; - _exchange = exchange; - _routingKey = routingKey; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _replyText ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchBasicReturn(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicReturnBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelCloseBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelCloseBodyImpl.java deleted file mode 100644 index ceadeb8f7c..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelCloseBodyImpl.java +++ /dev/null @@ -1,148 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelCloseBodyImpl extends AMQMethodBody_0_9 implements ChannelCloseBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelCloseBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final int _classId; // [classId] - private final int _methodId; // [methodId] - - // Constructor - public ChannelCloseBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _classId = readUnsignedShort( buffer ); - _methodId = readUnsignedShort( buffer ); - } - - public ChannelCloseBodyImpl( - int replyCode, - AMQShortString replyText, - int classId, - int methodId - ) - { - _replyCode = replyCode; - _replyText = replyText; - _classId = classId; - _methodId = methodId; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final int getClassId() - { - return _classId; - } - public final int getMethodId() - { - return _methodId; - } - - protected int getBodySize() - { - int size = 6; - size += getSizeOf( _replyText ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeUnsignedShort( buffer, _classId ); - writeUnsignedShort( buffer, _methodId ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchChannelClose(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelCloseBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "classId=" ); - buf.append( getClassId() ); - buf.append( ", " ); - buf.append( "methodId=" ); - buf.append( getMethodId() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelCloseOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelCloseOkBodyImpl.java deleted file mode 100644 index 5df83134f7..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelCloseOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelCloseOkBodyImpl extends AMQMethodBody_0_9 implements ChannelCloseOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelCloseOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 41; - - // Fields declared in specification - - // Constructor - public ChannelCloseOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ChannelCloseOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchChannelCloseOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelCloseOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelFlowBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelFlowBodyImpl.java deleted file mode 100644 index 62e9bf90a0..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelFlowBodyImpl.java +++ /dev/null @@ -1,116 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelFlowBodyImpl extends AMQMethodBody_0_9 implements ChannelFlowBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelFlowBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final byte _bitfield0; // [active] - - // Constructor - public ChannelFlowBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _bitfield0 = readBitfield( buffer ); - } - - public ChannelFlowBodyImpl( - boolean active - ) - { - byte bitfield0 = (byte)0; - if( active ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final boolean getActive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchChannelFlow(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelFlowBodyImpl: "); - buf.append( "active=" ); - buf.append( getActive() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelFlowOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelFlowOkBodyImpl.java deleted file mode 100644 index 5c73bd2ff4..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelFlowOkBodyImpl.java +++ /dev/null @@ -1,116 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelFlowOkBodyImpl extends AMQMethodBody_0_9 implements ChannelFlowOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelFlowOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final byte _bitfield0; // [active] - - // Constructor - public ChannelFlowOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _bitfield0 = readBitfield( buffer ); - } - - public ChannelFlowOkBodyImpl( - boolean active - ) - { - byte bitfield0 = (byte)0; - if( active ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final boolean getActive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchChannelFlowOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelFlowOkBodyImpl: "); - buf.append( "active=" ); - buf.append( getActive() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelOkBodyImpl.java deleted file mode 100644 index 7945fcec47..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelOkBodyImpl extends AMQMethodBody_0_9 implements ChannelOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 80; - - // Fields declared in specification - - // Constructor - public ChannelOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ChannelOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchChannelOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelOpenBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelOpenBodyImpl.java deleted file mode 100644 index 10c06cb132..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelOpenBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelOpenBodyImpl extends AMQMethodBody_0_9 implements ChannelOpenBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelOpenBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final AMQShortString _outOfBand; // [outOfBand] - - // Constructor - public ChannelOpenBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _outOfBand = readAMQShortString( buffer ); - } - - public ChannelOpenBodyImpl( - AMQShortString outOfBand - ) - { - _outOfBand = outOfBand; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getOutOfBand() - { - return _outOfBand; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _outOfBand ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _outOfBand ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchChannelOpen(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelOpenBodyImpl: "); - buf.append( "outOfBand=" ); - buf.append( getOutOfBand() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelOpenOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelOpenOkBodyImpl.java deleted file mode 100644 index 1c2a3f4a57..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelOpenOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelOpenOkBodyImpl extends AMQMethodBody_0_9 implements ChannelOpenOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelOpenOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 11; - - // Fields declared in specification - private final byte[] _channelId; // [channelId] - - // Constructor - public ChannelOpenOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _channelId = readBytes( buffer ); - } - - public ChannelOpenOkBodyImpl( - byte[] channelId - ) - { - _channelId = channelId; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getChannelId() - { - return _channelId; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _channelId ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _channelId ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchChannelOpenOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelOpenOkBodyImpl: "); - buf.append( "channelId=" ); - buf.append( getChannelId() == null ? "null" : java.util.Arrays.toString( getChannelId() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelPingBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelPingBodyImpl.java deleted file mode 100644 index ba02f17b99..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelPingBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelPingBodyImpl extends AMQMethodBody_0_9 implements ChannelPingBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelPingBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 60; - - // Fields declared in specification - - // Constructor - public ChannelPingBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ChannelPingBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchChannelPing(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelPingBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelPongBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelPongBodyImpl.java deleted file mode 100644 index da37e5127e..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelPongBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelPongBodyImpl extends AMQMethodBody_0_9 implements ChannelPongBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelPongBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 70; - - // Fields declared in specification - - // Constructor - public ChannelPongBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ChannelPongBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchChannelPong(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelPongBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelResumeBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelResumeBodyImpl.java deleted file mode 100644 index 47fc5c60be..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ChannelResumeBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelResumeBodyImpl extends AMQMethodBody_0_9 implements ChannelResumeBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelResumeBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 50; - - // Fields declared in specification - private final byte[] _channelId; // [channelId] - - // Constructor - public ChannelResumeBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _channelId = readBytes( buffer ); - } - - public ChannelResumeBodyImpl( - byte[] channelId - ) - { - _channelId = channelId; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getChannelId() - { - return _channelId; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _channelId ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _channelId ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchChannelResume(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelResumeBodyImpl: "); - buf.append( "channelId=" ); - buf.append( getChannelId() == null ? "null" : java.util.Arrays.toString( getChannelId() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ClientMethodDispatcher_0_9.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ClientMethodDispatcher_0_9.java deleted file mode 100644 index f1bf0d5a53..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ClientMethodDispatcher_0_9.java +++ /dev/null @@ -1,97 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.*; - -public interface ClientMethodDispatcher_0_9 extends ClientMethodDispatcher -{ - - public boolean dispatchAccessRequestOk(AccessRequestOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicCancelOk(BasicCancelOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicConsumeOk(BasicConsumeOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicDeliver(BasicDeliverBody body, int channelId) throws AMQException; - public boolean dispatchBasicGetEmpty(BasicGetEmptyBody body, int channelId) throws AMQException; - public boolean dispatchBasicGetOk(BasicGetOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicQosOk(BasicQosOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicRecoverSyncOk(BasicRecoverSyncOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicReturn(BasicReturnBody body, int channelId) throws AMQException; - public boolean dispatchChannelClose(ChannelCloseBody body, int channelId) throws AMQException; - public boolean dispatchChannelCloseOk(ChannelCloseOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelFlow(ChannelFlowBody body, int channelId) throws AMQException; - public boolean dispatchChannelFlowOk(ChannelFlowOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelOk(ChannelOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelOpenOk(ChannelOpenOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelPing(ChannelPingBody body, int channelId) throws AMQException; - public boolean dispatchChannelPong(ChannelPongBody body, int channelId) throws AMQException; - public boolean dispatchConnectionClose(ConnectionCloseBody body, int channelId) throws AMQException; - public boolean dispatchConnectionCloseOk(ConnectionCloseOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionOpenOk(ConnectionOpenOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionRedirect(ConnectionRedirectBody body, int channelId) throws AMQException; - public boolean dispatchConnectionSecure(ConnectionSecureBody body, int channelId) throws AMQException; - public boolean dispatchConnectionStart(ConnectionStartBody body, int channelId) throws AMQException; - public boolean dispatchConnectionTune(ConnectionTuneBody body, int channelId) throws AMQException; - public boolean dispatchDtxSelectOk(DtxSelectOkBody body, int channelId) throws AMQException; - public boolean dispatchDtxStartOk(DtxStartOkBody body, int channelId) throws AMQException; - public boolean dispatchExchangeBoundOk(ExchangeBoundOkBody body, int channelId) throws AMQException; - public boolean dispatchExchangeDeclareOk(ExchangeDeclareOkBody body, int channelId) throws AMQException; - public boolean dispatchExchangeDeleteOk(ExchangeDeleteOkBody body, int channelId) throws AMQException; - public boolean dispatchFileCancelOk(FileCancelOkBody body, int channelId) throws AMQException; - public boolean dispatchFileConsumeOk(FileConsumeOkBody body, int channelId) throws AMQException; - public boolean dispatchFileDeliver(FileDeliverBody body, int channelId) throws AMQException; - public boolean dispatchFileOpen(FileOpenBody body, int channelId) throws AMQException; - public boolean dispatchFileOpenOk(FileOpenOkBody body, int channelId) throws AMQException; - public boolean dispatchFileQosOk(FileQosOkBody body, int channelId) throws AMQException; - public boolean dispatchFileReturn(FileReturnBody body, int channelId) throws AMQException; - public boolean dispatchFileStage(FileStageBody body, int channelId) throws AMQException; - public boolean dispatchMessageAppend(MessageAppendBody body, int channelId) throws AMQException; - public boolean dispatchMessageCheckpoint(MessageCheckpointBody body, int channelId) throws AMQException; - public boolean dispatchMessageClose(MessageCloseBody body, int channelId) throws AMQException; - public boolean dispatchMessageEmpty(MessageEmptyBody body, int channelId) throws AMQException; - public boolean dispatchMessageOffset(MessageOffsetBody body, int channelId) throws AMQException; - public boolean dispatchMessageOk(MessageOkBody body, int channelId) throws AMQException; - public boolean dispatchMessageOpen(MessageOpenBody body, int channelId) throws AMQException; - public boolean dispatchMessageReject(MessageRejectBody body, int channelId) throws AMQException; - public boolean dispatchMessageResume(MessageResumeBody body, int channelId) throws AMQException; - public boolean dispatchMessageTransfer(MessageTransferBody body, int channelId) throws AMQException; - public boolean dispatchQueueBindOk(QueueBindOkBody body, int channelId) throws AMQException; - public boolean dispatchQueueDeclareOk(QueueDeclareOkBody body, int channelId) throws AMQException; - public boolean dispatchQueueDeleteOk(QueueDeleteOkBody body, int channelId) throws AMQException; - public boolean dispatchQueuePurgeOk(QueuePurgeOkBody body, int channelId) throws AMQException; - public boolean dispatchQueueUnbindOk(QueueUnbindOkBody body, int channelId) throws AMQException; - public boolean dispatchStreamCancelOk(StreamCancelOkBody body, int channelId) throws AMQException; - public boolean dispatchStreamConsumeOk(StreamConsumeOkBody body, int channelId) throws AMQException; - public boolean dispatchStreamDeliver(StreamDeliverBody body, int channelId) throws AMQException; - public boolean dispatchStreamQosOk(StreamQosOkBody body, int channelId) throws AMQException; - public boolean dispatchStreamReturn(StreamReturnBody body, int channelId) throws AMQException; - public boolean dispatchTxCommitOk(TxCommitOkBody body, int channelId) throws AMQException; - public boolean dispatchTxRollbackOk(TxRollbackOkBody body, int channelId) throws AMQException; - public boolean dispatchTxSelectOk(TxSelectOkBody body, int channelId) throws AMQException; - -}
\ No newline at end of file diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionCloseBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionCloseBodyImpl.java deleted file mode 100644 index e0f8704f67..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionCloseBodyImpl.java +++ /dev/null @@ -1,148 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionCloseBodyImpl extends AMQMethodBody_0_9 implements ConnectionCloseBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionCloseBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 50; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final int _classId; // [classId] - private final int _methodId; // [methodId] - - // Constructor - public ConnectionCloseBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _classId = readUnsignedShort( buffer ); - _methodId = readUnsignedShort( buffer ); - } - - public ConnectionCloseBodyImpl( - int replyCode, - AMQShortString replyText, - int classId, - int methodId - ) - { - _replyCode = replyCode; - _replyText = replyText; - _classId = classId; - _methodId = methodId; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final int getClassId() - { - return _classId; - } - public final int getMethodId() - { - return _methodId; - } - - protected int getBodySize() - { - int size = 6; - size += getSizeOf( _replyText ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeUnsignedShort( buffer, _classId ); - writeUnsignedShort( buffer, _methodId ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchConnectionClose(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionCloseBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "classId=" ); - buf.append( getClassId() ); - buf.append( ", " ); - buf.append( "methodId=" ); - buf.append( getMethodId() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionCloseOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionCloseOkBodyImpl.java deleted file mode 100644 index 98f73b0beb..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionCloseOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionCloseOkBodyImpl extends AMQMethodBody_0_9 implements ConnectionCloseOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionCloseOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 51; - - // Fields declared in specification - - // Constructor - public ConnectionCloseOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ConnectionCloseOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchConnectionCloseOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionCloseOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionOpenBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionOpenBodyImpl.java deleted file mode 100644 index 86c40656bb..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionOpenBodyImpl.java +++ /dev/null @@ -1,142 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionOpenBodyImpl extends AMQMethodBody_0_9 implements ConnectionOpenBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionOpenBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final AMQShortString _virtualHost; // [virtualHost] - private final AMQShortString _capabilities; // [capabilities] - private final byte _bitfield0; // [insist] - - // Constructor - public ConnectionOpenBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _virtualHost = readAMQShortString( buffer ); - _capabilities = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public ConnectionOpenBodyImpl( - AMQShortString virtualHost, - AMQShortString capabilities, - boolean insist - ) - { - _virtualHost = virtualHost; - _capabilities = capabilities; - byte bitfield0 = (byte)0; - if( insist ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getVirtualHost() - { - return _virtualHost; - } - public final AMQShortString getCapabilities() - { - return _capabilities; - } - public final boolean getInsist() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - size += getSizeOf( _virtualHost ); - size += getSizeOf( _capabilities ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _virtualHost ); - writeAMQShortString( buffer, _capabilities ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchConnectionOpen(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionOpenBodyImpl: "); - buf.append( "virtualHost=" ); - buf.append( getVirtualHost() ); - buf.append( ", " ); - buf.append( "capabilities=" ); - buf.append( getCapabilities() ); - buf.append( ", " ); - buf.append( "insist=" ); - buf.append( getInsist() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionOpenOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionOpenOkBodyImpl.java deleted file mode 100644 index 0439fc01b8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionOpenOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionOpenOkBodyImpl extends AMQMethodBody_0_9 implements ConnectionOpenOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionOpenOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 41; - - // Fields declared in specification - private final AMQShortString _knownHosts; // [knownHosts] - - // Constructor - public ConnectionOpenOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _knownHosts = readAMQShortString( buffer ); - } - - public ConnectionOpenOkBodyImpl( - AMQShortString knownHosts - ) - { - _knownHosts = knownHosts; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getKnownHosts() - { - return _knownHosts; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _knownHosts ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _knownHosts ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchConnectionOpenOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionOpenOkBodyImpl: "); - buf.append( "knownHosts=" ); - buf.append( getKnownHosts() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionRedirectBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionRedirectBodyImpl.java deleted file mode 100644 index 270161db47..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionRedirectBodyImpl.java +++ /dev/null @@ -1,125 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionRedirectBodyImpl extends AMQMethodBody_0_9 implements ConnectionRedirectBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionRedirectBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 42; - - // Fields declared in specification - private final AMQShortString _host; // [host] - private final AMQShortString _knownHosts; // [knownHosts] - - // Constructor - public ConnectionRedirectBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _host = readAMQShortString( buffer ); - _knownHosts = readAMQShortString( buffer ); - } - - public ConnectionRedirectBodyImpl( - AMQShortString host, - AMQShortString knownHosts - ) - { - _host = host; - _knownHosts = knownHosts; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getHost() - { - return _host; - } - public final AMQShortString getKnownHosts() - { - return _knownHosts; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _host ); - size += getSizeOf( _knownHosts ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _host ); - writeAMQShortString( buffer, _knownHosts ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchConnectionRedirect(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionRedirectBodyImpl: "); - buf.append( "host=" ); - buf.append( getHost() ); - buf.append( ", " ); - buf.append( "knownHosts=" ); - buf.append( getKnownHosts() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionSecureBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionSecureBodyImpl.java deleted file mode 100644 index 19b9532f5b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionSecureBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionSecureBodyImpl extends AMQMethodBody_0_9 implements ConnectionSecureBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionSecureBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final byte[] _challenge; // [challenge] - - // Constructor - public ConnectionSecureBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _challenge = readBytes( buffer ); - } - - public ConnectionSecureBodyImpl( - byte[] challenge - ) - { - _challenge = challenge; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getChallenge() - { - return _challenge; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _challenge ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _challenge ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchConnectionSecure(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionSecureBodyImpl: "); - buf.append( "challenge=" ); - buf.append( getChallenge() == null ? "null" : java.util.Arrays.toString( getChallenge() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionSecureOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionSecureOkBodyImpl.java deleted file mode 100644 index 7891d7d24c..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionSecureOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionSecureOkBodyImpl extends AMQMethodBody_0_9 implements ConnectionSecureOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionSecureOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final byte[] _response; // [response] - - // Constructor - public ConnectionSecureOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _response = readBytes( buffer ); - } - - public ConnectionSecureOkBodyImpl( - byte[] response - ) - { - _response = response; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getResponse() - { - return _response; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _response ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _response ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchConnectionSecureOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionSecureOkBodyImpl: "); - buf.append( "response=" ); - buf.append( getResponse() == null ? "null" : java.util.Arrays.toString( getResponse() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionStartBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionStartBodyImpl.java deleted file mode 100644 index ec82327f4d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionStartBodyImpl.java +++ /dev/null @@ -1,162 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionStartBodyImpl extends AMQMethodBody_0_9 implements ConnectionStartBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionStartBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final short _versionMajor; // [versionMajor] - private final short _versionMinor; // [versionMinor] - private final FieldTable _serverProperties; // [serverProperties] - private final byte[] _mechanisms; // [mechanisms] - private final byte[] _locales; // [locales] - - // Constructor - public ConnectionStartBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _versionMajor = readUnsignedByte( buffer ); - _versionMinor = readUnsignedByte( buffer ); - _serverProperties = readFieldTable( buffer ); - _mechanisms = readBytes( buffer ); - _locales = readBytes( buffer ); - } - - public ConnectionStartBodyImpl( - short versionMajor, - short versionMinor, - FieldTable serverProperties, - byte[] mechanisms, - byte[] locales - ) - { - _versionMajor = versionMajor; - _versionMinor = versionMinor; - _serverProperties = serverProperties; - _mechanisms = mechanisms; - _locales = locales; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final short getVersionMajor() - { - return _versionMajor; - } - public final short getVersionMinor() - { - return _versionMinor; - } - public final FieldTable getServerProperties() - { - return _serverProperties; - } - public final byte[] getMechanisms() - { - return _mechanisms; - } - public final byte[] getLocales() - { - return _locales; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _serverProperties ); - size += getSizeOf( _mechanisms ); - size += getSizeOf( _locales ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedByte( buffer, _versionMajor ); - writeUnsignedByte( buffer, _versionMinor ); - writeFieldTable( buffer, _serverProperties ); - writeBytes( buffer, _mechanisms ); - writeBytes( buffer, _locales ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchConnectionStart(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionStartBodyImpl: "); - buf.append( "versionMajor=" ); - buf.append( getVersionMajor() ); - buf.append( ", " ); - buf.append( "versionMinor=" ); - buf.append( getVersionMinor() ); - buf.append( ", " ); - buf.append( "serverProperties=" ); - buf.append( getServerProperties() ); - buf.append( ", " ); - buf.append( "mechanisms=" ); - buf.append( getMechanisms() == null ? "null" : java.util.Arrays.toString( getMechanisms() ) ); - buf.append( ", " ); - buf.append( "locales=" ); - buf.append( getLocales() == null ? "null" : java.util.Arrays.toString( getLocales() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionStartOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionStartOkBodyImpl.java deleted file mode 100644 index cdc77c87fd..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionStartOkBodyImpl.java +++ /dev/null @@ -1,151 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionStartOkBodyImpl extends AMQMethodBody_0_9 implements ConnectionStartOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionStartOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 11; - - // Fields declared in specification - private final FieldTable _clientProperties; // [clientProperties] - private final AMQShortString _mechanism; // [mechanism] - private final byte[] _response; // [response] - private final AMQShortString _locale; // [locale] - - // Constructor - public ConnectionStartOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _clientProperties = readFieldTable( buffer ); - _mechanism = readAMQShortString( buffer ); - _response = readBytes( buffer ); - _locale = readAMQShortString( buffer ); - } - - public ConnectionStartOkBodyImpl( - FieldTable clientProperties, - AMQShortString mechanism, - byte[] response, - AMQShortString locale - ) - { - _clientProperties = clientProperties; - _mechanism = mechanism; - _response = response; - _locale = locale; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final FieldTable getClientProperties() - { - return _clientProperties; - } - public final AMQShortString getMechanism() - { - return _mechanism; - } - public final byte[] getResponse() - { - return _response; - } - public final AMQShortString getLocale() - { - return _locale; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _clientProperties ); - size += getSizeOf( _mechanism ); - size += getSizeOf( _response ); - size += getSizeOf( _locale ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeFieldTable( buffer, _clientProperties ); - writeAMQShortString( buffer, _mechanism ); - writeBytes( buffer, _response ); - writeAMQShortString( buffer, _locale ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchConnectionStartOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionStartOkBodyImpl: "); - buf.append( "clientProperties=" ); - buf.append( getClientProperties() ); - buf.append( ", " ); - buf.append( "mechanism=" ); - buf.append( getMechanism() ); - buf.append( ", " ); - buf.append( "response=" ); - buf.append( getResponse() == null ? "null" : java.util.Arrays.toString( getResponse() ) ); - buf.append( ", " ); - buf.append( "locale=" ); - buf.append( getLocale() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionTuneBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionTuneBodyImpl.java deleted file mode 100644 index a5cb1f4d77..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionTuneBodyImpl.java +++ /dev/null @@ -1,135 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionTuneBodyImpl extends AMQMethodBody_0_9 implements ConnectionTuneBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionTuneBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final int _channelMax; // [channelMax] - private final long _frameMax; // [frameMax] - private final int _heartbeat; // [heartbeat] - - // Constructor - public ConnectionTuneBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _channelMax = readUnsignedShort( buffer ); - _frameMax = readUnsignedInteger( buffer ); - _heartbeat = readUnsignedShort( buffer ); - } - - public ConnectionTuneBodyImpl( - int channelMax, - long frameMax, - int heartbeat - ) - { - _channelMax = channelMax; - _frameMax = frameMax; - _heartbeat = heartbeat; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getChannelMax() - { - return _channelMax; - } - public final long getFrameMax() - { - return _frameMax; - } - public final int getHeartbeat() - { - return _heartbeat; - } - - protected int getBodySize() - { - int size = 8; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _channelMax ); - writeUnsignedInteger( buffer, _frameMax ); - writeUnsignedShort( buffer, _heartbeat ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchConnectionTune(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionTuneBodyImpl: "); - buf.append( "channelMax=" ); - buf.append( getChannelMax() ); - buf.append( ", " ); - buf.append( "frameMax=" ); - buf.append( getFrameMax() ); - buf.append( ", " ); - buf.append( "heartbeat=" ); - buf.append( getHeartbeat() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionTuneOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionTuneOkBodyImpl.java deleted file mode 100644 index 2dee4765f5..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ConnectionTuneOkBodyImpl.java +++ /dev/null @@ -1,135 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionTuneOkBodyImpl extends AMQMethodBody_0_9 implements ConnectionTuneOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionTuneOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final int _channelMax; // [channelMax] - private final long _frameMax; // [frameMax] - private final int _heartbeat; // [heartbeat] - - // Constructor - public ConnectionTuneOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _channelMax = readUnsignedShort( buffer ); - _frameMax = readUnsignedInteger( buffer ); - _heartbeat = readUnsignedShort( buffer ); - } - - public ConnectionTuneOkBodyImpl( - int channelMax, - long frameMax, - int heartbeat - ) - { - _channelMax = channelMax; - _frameMax = frameMax; - _heartbeat = heartbeat; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getChannelMax() - { - return _channelMax; - } - public final long getFrameMax() - { - return _frameMax; - } - public final int getHeartbeat() - { - return _heartbeat; - } - - protected int getBodySize() - { - int size = 8; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _channelMax ); - writeUnsignedInteger( buffer, _frameMax ); - writeUnsignedShort( buffer, _heartbeat ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchConnectionTuneOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionTuneOkBodyImpl: "); - buf.append( "channelMax=" ); - buf.append( getChannelMax() ); - buf.append( ", " ); - buf.append( "frameMax=" ); - buf.append( getFrameMax() ); - buf.append( ", " ); - buf.append( "heartbeat=" ); - buf.append( getHeartbeat() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/DtxSelectBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/DtxSelectBodyImpl.java deleted file mode 100644 index 5739697389..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/DtxSelectBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class DtxSelectBodyImpl extends AMQMethodBody_0_9 implements DtxSelectBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new DtxSelectBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 100; - public static final int METHOD_ID = 10; - - // Fields declared in specification - - // Constructor - public DtxSelectBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public DtxSelectBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchDtxSelect(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[DtxSelectBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/DtxSelectOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/DtxSelectOkBodyImpl.java deleted file mode 100644 index b379501617..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/DtxSelectOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class DtxSelectOkBodyImpl extends AMQMethodBody_0_9 implements DtxSelectOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new DtxSelectOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 100; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public DtxSelectOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public DtxSelectOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchDtxSelectOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[DtxSelectOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/DtxStartBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/DtxStartBodyImpl.java deleted file mode 100644 index 162c0b31ad..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/DtxStartBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class DtxStartBodyImpl extends AMQMethodBody_0_9 implements DtxStartBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new DtxStartBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 100; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final AMQShortString _dtxIdentifier; // [dtxIdentifier] - - // Constructor - public DtxStartBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _dtxIdentifier = readAMQShortString( buffer ); - } - - public DtxStartBodyImpl( - AMQShortString dtxIdentifier - ) - { - _dtxIdentifier = dtxIdentifier; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getDtxIdentifier() - { - return _dtxIdentifier; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _dtxIdentifier ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _dtxIdentifier ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchDtxStart(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[DtxStartBodyImpl: "); - buf.append( "dtxIdentifier=" ); - buf.append( getDtxIdentifier() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/DtxStartOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/DtxStartOkBodyImpl.java deleted file mode 100644 index fbe9b86e56..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/DtxStartOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class DtxStartOkBodyImpl extends AMQMethodBody_0_9 implements DtxStartOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new DtxStartOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 100; - public static final int METHOD_ID = 21; - - // Fields declared in specification - - // Constructor - public DtxStartOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public DtxStartOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchDtxStartOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[DtxStartOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeBoundBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeBoundBodyImpl.java deleted file mode 100644 index 92ba4edc03..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeBoundBodyImpl.java +++ /dev/null @@ -1,138 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeBoundBodyImpl extends AMQMethodBody_0_9 implements ExchangeBoundBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeBoundBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 22; - - // Fields declared in specification - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final AMQShortString _queue; // [queue] - - // Constructor - public ExchangeBoundBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _queue = readAMQShortString( buffer ); - } - - public ExchangeBoundBodyImpl( - AMQShortString exchange, - AMQShortString routingKey, - AMQShortString queue - ) - { - _exchange = exchange; - _routingKey = routingKey; - _queue = queue; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final AMQShortString getQueue() - { - return _queue; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeAMQShortString( buffer, _queue ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchExchangeBound(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeBoundBodyImpl: "); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeBoundOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeBoundOkBodyImpl.java deleted file mode 100644 index 4f594b9a70..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeBoundOkBodyImpl.java +++ /dev/null @@ -1,124 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeBoundOkBodyImpl extends AMQMethodBody_0_9 implements ExchangeBoundOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeBoundOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 23; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - - // Constructor - public ExchangeBoundOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - } - - public ExchangeBoundOkBodyImpl( - int replyCode, - AMQShortString replyText - ) - { - _replyCode = replyCode; - _replyText = replyText; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _replyText ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchExchangeBoundOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeBoundOkBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeDeclareBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeDeclareBodyImpl.java deleted file mode 100644 index 50b6889735..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeDeclareBodyImpl.java +++ /dev/null @@ -1,220 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeDeclareBodyImpl extends AMQMethodBody_0_9 implements ExchangeDeclareBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeDeclareBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _type; // [type] - private final byte _bitfield0; // [passive, durable, autoDelete, internal, nowait] - private final FieldTable _arguments; // [arguments] - - // Constructor - public ExchangeDeclareBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _exchange = readAMQShortString( buffer ); - _type = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _arguments = readFieldTable( buffer ); - } - - public ExchangeDeclareBodyImpl( - int ticket, - AMQShortString exchange, - AMQShortString type, - boolean passive, - boolean durable, - boolean autoDelete, - boolean internal, - boolean nowait, - FieldTable arguments - ) - { - _ticket = ticket; - _exchange = exchange; - _type = type; - byte bitfield0 = (byte)0; - if( passive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( durable ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( autoDelete ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - if( internal ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 4)); - } - - _bitfield0 = bitfield0; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getType() - { - return _type; - } - public final boolean getPassive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getDurable() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getAutoDelete() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final boolean getInternal() - { - return (((int)(_bitfield0)) & ( 1 << 3)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 4)) != 0; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _exchange ); - size += getSizeOf( _type ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _type ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchExchangeDeclare(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeDeclareBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "type=" ); - buf.append( getType() ); - buf.append( ", " ); - buf.append( "passive=" ); - buf.append( getPassive() ); - buf.append( ", " ); - buf.append( "durable=" ); - buf.append( getDurable() ); - buf.append( ", " ); - buf.append( "autoDelete=" ); - buf.append( getAutoDelete() ); - buf.append( ", " ); - buf.append( "internal=" ); - buf.append( getInternal() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeDeclareOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeDeclareOkBodyImpl.java deleted file mode 100644 index adaff55cc8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeDeclareOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeDeclareOkBodyImpl extends AMQMethodBody_0_9 implements ExchangeDeclareOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeDeclareOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public ExchangeDeclareOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ExchangeDeclareOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchExchangeDeclareOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeDeclareOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeDeleteBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeDeleteBodyImpl.java deleted file mode 100644 index 60da6c8330..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeDeleteBodyImpl.java +++ /dev/null @@ -1,154 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeDeleteBodyImpl extends AMQMethodBody_0_9 implements ExchangeDeleteBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeDeleteBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _exchange; // [exchange] - private final byte _bitfield0; // [ifUnused, nowait] - - // Constructor - public ExchangeDeleteBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _exchange = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public ExchangeDeleteBodyImpl( - int ticket, - AMQShortString exchange, - boolean ifUnused, - boolean nowait - ) - { - _ticket = ticket; - _exchange = exchange; - byte bitfield0 = (byte)0; - if( ifUnused ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final boolean getIfUnused() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _exchange ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _exchange ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchExchangeDelete(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeDeleteBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "ifUnused=" ); - buf.append( getIfUnused() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeDeleteOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeDeleteOkBodyImpl.java deleted file mode 100644 index 89eab25c74..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ExchangeDeleteOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeDeleteOkBodyImpl extends AMQMethodBody_0_9 implements ExchangeDeleteOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeDeleteOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 21; - - // Fields declared in specification - - // Constructor - public ExchangeDeleteOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ExchangeDeleteOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchExchangeDeleteOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeDeleteOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileAckBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileAckBodyImpl.java deleted file mode 100644 index b2e0727fc3..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileAckBodyImpl.java +++ /dev/null @@ -1,128 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileAckBodyImpl extends AMQMethodBody_0_9 implements FileAckBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileAckBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 90; - - // Fields declared in specification - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [multiple] - - // Constructor - public FileAckBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public FileAckBodyImpl( - long deliveryTag, - boolean multiple - ) - { - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( multiple ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getMultiple() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 9; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFileAck(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileAckBodyImpl: "); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "multiple=" ); - buf.append( getMultiple() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileCancelBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileCancelBodyImpl.java deleted file mode 100644 index a1cddb1bc1..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileCancelBodyImpl.java +++ /dev/null @@ -1,129 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileCancelBodyImpl extends AMQMethodBody_0_9 implements FileCancelBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileCancelBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [nowait] - - // Constructor - public FileCancelBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public FileCancelBodyImpl( - AMQShortString consumerTag, - boolean nowait - ) - { - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFileCancel(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileCancelBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileCancelOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileCancelOkBodyImpl.java deleted file mode 100644 index 258b55f6d8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileCancelOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileCancelOkBodyImpl extends AMQMethodBody_0_9 implements FileCancelOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileCancelOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public FileCancelOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public FileCancelOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFileCancelOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileCancelOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileConsumeBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileConsumeBodyImpl.java deleted file mode 100644 index d841fab69d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileConsumeBodyImpl.java +++ /dev/null @@ -1,207 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileConsumeBodyImpl extends AMQMethodBody_0_9 implements FileConsumeBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileConsumeBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [noLocal, noAck, exclusive, nowait] - private final FieldTable _filter; // [filter] - - // Constructor - public FileConsumeBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _filter = readFieldTable( buffer ); - } - - public FileConsumeBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString consumerTag, - boolean noLocal, - boolean noAck, - boolean exclusive, - boolean nowait, - FieldTable filter - ) - { - _ticket = ticket; - _queue = queue; - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( noLocal ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( noAck ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( exclusive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); - } - - _bitfield0 = bitfield0; - _filter = filter; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNoLocal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getNoAck() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getExclusive() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 3)) != 0; - } - public final FieldTable getFilter() - { - return _filter; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _consumerTag ); - size += getSizeOf( _filter ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _filter ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFileConsume(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileConsumeBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "noLocal=" ); - buf.append( getNoLocal() ); - buf.append( ", " ); - buf.append( "noAck=" ); - buf.append( getNoAck() ); - buf.append( ", " ); - buf.append( "exclusive=" ); - buf.append( getExclusive() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "filter=" ); - buf.append( getFilter() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileConsumeOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileConsumeOkBodyImpl.java deleted file mode 100644 index 139ab0cbce..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileConsumeOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileConsumeOkBodyImpl extends AMQMethodBody_0_9 implements FileConsumeOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileConsumeOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public FileConsumeOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public FileConsumeOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFileConsumeOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileConsumeOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileDeliverBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileDeliverBodyImpl.java deleted file mode 100644 index 5e4b15ef74..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileDeliverBodyImpl.java +++ /dev/null @@ -1,181 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileDeliverBodyImpl extends AMQMethodBody_0_9 implements FileDeliverBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileDeliverBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 80; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [redelivered] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final AMQShortString _identifier; // [identifier] - - // Constructor - public FileDeliverBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _identifier = readAMQShortString( buffer ); - } - - public FileDeliverBodyImpl( - AMQShortString consumerTag, - long deliveryTag, - boolean redelivered, - AMQShortString exchange, - AMQShortString routingKey, - AMQShortString identifier - ) - { - _consumerTag = consumerTag; - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( redelivered ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - _bitfield0 = bitfield0; - _exchange = exchange; - _routingKey = routingKey; - _identifier = identifier; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getRedelivered() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final AMQShortString getIdentifier() - { - return _identifier; - } - - protected int getBodySize() - { - int size = 9; - size += getSizeOf( _consumerTag ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - size += getSizeOf( _identifier ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeAMQShortString( buffer, _identifier ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFileDeliver(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileDeliverBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "redelivered=" ); - buf.append( getRedelivered() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "identifier=" ); - buf.append( getIdentifier() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileOpenBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileOpenBodyImpl.java deleted file mode 100644 index 7c2352eee3..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileOpenBodyImpl.java +++ /dev/null @@ -1,124 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileOpenBodyImpl extends AMQMethodBody_0_9 implements FileOpenBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileOpenBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final AMQShortString _identifier; // [identifier] - private final long _contentSize; // [contentSize] - - // Constructor - public FileOpenBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _identifier = readAMQShortString( buffer ); - _contentSize = readLong( buffer ); - } - - public FileOpenBodyImpl( - AMQShortString identifier, - long contentSize - ) - { - _identifier = identifier; - _contentSize = contentSize; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getIdentifier() - { - return _identifier; - } - public final long getContentSize() - { - return _contentSize; - } - - protected int getBodySize() - { - int size = 8; - size += getSizeOf( _identifier ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _identifier ); - writeLong( buffer, _contentSize ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFileOpen(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileOpenBodyImpl: "); - buf.append( "identifier=" ); - buf.append( getIdentifier() ); - buf.append( ", " ); - buf.append( "contentSize=" ); - buf.append( getContentSize() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileOpenOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileOpenOkBodyImpl.java deleted file mode 100644 index 05a132cce2..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileOpenOkBodyImpl.java +++ /dev/null @@ -1,111 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileOpenOkBodyImpl extends AMQMethodBody_0_9 implements FileOpenOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileOpenOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 41; - - // Fields declared in specification - private final long _stagedSize; // [stagedSize] - - // Constructor - public FileOpenOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _stagedSize = readLong( buffer ); - } - - public FileOpenOkBodyImpl( - long stagedSize - ) - { - _stagedSize = stagedSize; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getStagedSize() - { - return _stagedSize; - } - - protected int getBodySize() - { - int size = 8; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _stagedSize ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFileOpenOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileOpenOkBodyImpl: "); - buf.append( "stagedSize=" ); - buf.append( getStagedSize() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FilePublishBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FilePublishBodyImpl.java deleted file mode 100644 index f04a869bcc..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FilePublishBodyImpl.java +++ /dev/null @@ -1,181 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FilePublishBodyImpl extends AMQMethodBody_0_9 implements FilePublishBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FilePublishBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 60; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final byte _bitfield0; // [mandatory, immediate] - private final AMQShortString _identifier; // [identifier] - - // Constructor - public FilePublishBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _identifier = readAMQShortString( buffer ); - } - - public FilePublishBodyImpl( - int ticket, - AMQShortString exchange, - AMQShortString routingKey, - boolean mandatory, - boolean immediate, - AMQShortString identifier - ) - { - _ticket = ticket; - _exchange = exchange; - _routingKey = routingKey; - byte bitfield0 = (byte)0; - if( mandatory ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( immediate ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - _bitfield0 = bitfield0; - _identifier = identifier; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final boolean getMandatory() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getImmediate() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final AMQShortString getIdentifier() - { - return _identifier; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - size += getSizeOf( _identifier ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeBitfield( buffer, _bitfield0 ); - writeAMQShortString( buffer, _identifier ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFilePublish(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FilePublishBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "mandatory=" ); - buf.append( getMandatory() ); - buf.append( ", " ); - buf.append( "immediate=" ); - buf.append( getImmediate() ); - buf.append( ", " ); - buf.append( "identifier=" ); - buf.append( getIdentifier() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileQosBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileQosBodyImpl.java deleted file mode 100644 index 0d6fe98029..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileQosBodyImpl.java +++ /dev/null @@ -1,140 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileQosBodyImpl extends AMQMethodBody_0_9 implements FileQosBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileQosBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final long _prefetchSize; // [prefetchSize] - private final int _prefetchCount; // [prefetchCount] - private final byte _bitfield0; // [global] - - // Constructor - public FileQosBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _prefetchSize = readUnsignedInteger( buffer ); - _prefetchCount = readUnsignedShort( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public FileQosBodyImpl( - long prefetchSize, - int prefetchCount, - boolean global - ) - { - _prefetchSize = prefetchSize; - _prefetchCount = prefetchCount; - byte bitfield0 = (byte)0; - if( global ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getPrefetchSize() - { - return _prefetchSize; - } - public final int getPrefetchCount() - { - return _prefetchCount; - } - public final boolean getGlobal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 7; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _prefetchSize ); - writeUnsignedShort( buffer, _prefetchCount ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFileQos(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileQosBodyImpl: "); - buf.append( "prefetchSize=" ); - buf.append( getPrefetchSize() ); - buf.append( ", " ); - buf.append( "prefetchCount=" ); - buf.append( getPrefetchCount() ); - buf.append( ", " ); - buf.append( "global=" ); - buf.append( getGlobal() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileQosOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileQosOkBodyImpl.java deleted file mode 100644 index b7703c633a..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileQosOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileQosOkBodyImpl extends AMQMethodBody_0_9 implements FileQosOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileQosOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public FileQosOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public FileQosOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFileQosOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileQosOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileRejectBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileRejectBodyImpl.java deleted file mode 100644 index b73014ebe2..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileRejectBodyImpl.java +++ /dev/null @@ -1,128 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileRejectBodyImpl extends AMQMethodBody_0_9 implements FileRejectBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileRejectBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 100; - - // Fields declared in specification - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [requeue] - - // Constructor - public FileRejectBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public FileRejectBodyImpl( - long deliveryTag, - boolean requeue - ) - { - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( requeue ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getRequeue() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 9; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFileReject(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileRejectBodyImpl: "); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "requeue=" ); - buf.append( getRequeue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileReturnBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileReturnBodyImpl.java deleted file mode 100644 index 4a0d600f13..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileReturnBodyImpl.java +++ /dev/null @@ -1,150 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileReturnBodyImpl extends AMQMethodBody_0_9 implements FileReturnBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileReturnBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 70; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - - // Constructor - public FileReturnBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - } - - public FileReturnBodyImpl( - int replyCode, - AMQShortString replyText, - AMQShortString exchange, - AMQShortString routingKey - ) - { - _replyCode = replyCode; - _replyText = replyText; - _exchange = exchange; - _routingKey = routingKey; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _replyText ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFileReturn(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileReturnBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileStageBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileStageBodyImpl.java deleted file mode 100644 index dfb76279e8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/FileStageBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileStageBodyImpl extends AMQMethodBody_0_9 implements FileStageBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileStageBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 50; - - // Fields declared in specification - - // Constructor - public FileStageBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public FileStageBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchFileStage(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileStageBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageAppendBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageAppendBodyImpl.java deleted file mode 100644 index 4964c77ab6..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageAppendBodyImpl.java +++ /dev/null @@ -1,125 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageAppendBodyImpl extends AMQMethodBody_0_9 implements MessageAppendBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageAppendBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 80; - - // Fields declared in specification - private final byte[] _reference; // [reference] - private final byte[] _bytes; // [bytes] - - // Constructor - public MessageAppendBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _reference = readBytes( buffer ); - _bytes = readBytes( buffer ); - } - - public MessageAppendBodyImpl( - byte[] reference, - byte[] bytes - ) - { - _reference = reference; - _bytes = bytes; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getReference() - { - return _reference; - } - public final byte[] getBytes() - { - return _bytes; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _reference ); - size += getSizeOf( _bytes ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _reference ); - writeBytes( buffer, _bytes ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageAppend(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageAppendBodyImpl: "); - buf.append( "reference=" ); - buf.append( getReference() == null ? "null" : java.util.Arrays.toString( getReference() ) ); - buf.append( ", " ); - buf.append( "bytes=" ); - buf.append( getBytes() == null ? "null" : java.util.Arrays.toString( getBytes() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageCancelBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageCancelBodyImpl.java deleted file mode 100644 index 661b6cd9a3..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageCancelBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageCancelBodyImpl extends AMQMethodBody_0_9 implements MessageCancelBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageCancelBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final AMQShortString _destination; // [destination] - - // Constructor - public MessageCancelBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _destination = readAMQShortString( buffer ); - } - - public MessageCancelBodyImpl( - AMQShortString destination - ) - { - _destination = destination; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getDestination() - { - return _destination; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _destination ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _destination ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageCancel(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageCancelBodyImpl: "); - buf.append( "destination=" ); - buf.append( getDestination() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageCheckpointBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageCheckpointBodyImpl.java deleted file mode 100644 index 921348ac71..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageCheckpointBodyImpl.java +++ /dev/null @@ -1,125 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageCheckpointBodyImpl extends AMQMethodBody_0_9 implements MessageCheckpointBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageCheckpointBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 90; - - // Fields declared in specification - private final byte[] _reference; // [reference] - private final AMQShortString _identifier; // [identifier] - - // Constructor - public MessageCheckpointBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _reference = readBytes( buffer ); - _identifier = readAMQShortString( buffer ); - } - - public MessageCheckpointBodyImpl( - byte[] reference, - AMQShortString identifier - ) - { - _reference = reference; - _identifier = identifier; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getReference() - { - return _reference; - } - public final AMQShortString getIdentifier() - { - return _identifier; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _reference ); - size += getSizeOf( _identifier ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _reference ); - writeAMQShortString( buffer, _identifier ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageCheckpoint(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageCheckpointBodyImpl: "); - buf.append( "reference=" ); - buf.append( getReference() == null ? "null" : java.util.Arrays.toString( getReference() ) ); - buf.append( ", " ); - buf.append( "identifier=" ); - buf.append( getIdentifier() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageCloseBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageCloseBodyImpl.java deleted file mode 100644 index 78185ec507..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageCloseBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageCloseBodyImpl extends AMQMethodBody_0_9 implements MessageCloseBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageCloseBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 70; - - // Fields declared in specification - private final byte[] _reference; // [reference] - - // Constructor - public MessageCloseBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _reference = readBytes( buffer ); - } - - public MessageCloseBodyImpl( - byte[] reference - ) - { - _reference = reference; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getReference() - { - return _reference; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _reference ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _reference ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageClose(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageCloseBodyImpl: "); - buf.append( "reference=" ); - buf.append( getReference() == null ? "null" : java.util.Arrays.toString( getReference() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageConsumeBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageConsumeBodyImpl.java deleted file mode 100644 index fe72503c17..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageConsumeBodyImpl.java +++ /dev/null @@ -1,194 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageConsumeBodyImpl extends AMQMethodBody_0_9 implements MessageConsumeBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageConsumeBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _destination; // [destination] - private final byte _bitfield0; // [noLocal, noAck, exclusive] - private final FieldTable _filter; // [filter] - - // Constructor - public MessageConsumeBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _destination = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _filter = readFieldTable( buffer ); - } - - public MessageConsumeBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString destination, - boolean noLocal, - boolean noAck, - boolean exclusive, - FieldTable filter - ) - { - _ticket = ticket; - _queue = queue; - _destination = destination; - byte bitfield0 = (byte)0; - if( noLocal ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( noAck ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( exclusive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - _bitfield0 = bitfield0; - _filter = filter; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getDestination() - { - return _destination; - } - public final boolean getNoLocal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getNoAck() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getExclusive() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final FieldTable getFilter() - { - return _filter; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _destination ); - size += getSizeOf( _filter ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _destination ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _filter ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageConsume(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageConsumeBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "destination=" ); - buf.append( getDestination() ); - buf.append( ", " ); - buf.append( "noLocal=" ); - buf.append( getNoLocal() ); - buf.append( ", " ); - buf.append( "noAck=" ); - buf.append( getNoAck() ); - buf.append( ", " ); - buf.append( "exclusive=" ); - buf.append( getExclusive() ); - buf.append( ", " ); - buf.append( "filter=" ); - buf.append( getFilter() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageEmptyBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageEmptyBodyImpl.java deleted file mode 100644 index 1383836f8e..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageEmptyBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageEmptyBodyImpl extends AMQMethodBody_0_9 implements MessageEmptyBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageEmptyBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 510; - - // Fields declared in specification - - // Constructor - public MessageEmptyBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public MessageEmptyBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageEmpty(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageEmptyBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageGetBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageGetBodyImpl.java deleted file mode 100644 index b812309ac0..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageGetBodyImpl.java +++ /dev/null @@ -1,154 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageGetBodyImpl extends AMQMethodBody_0_9 implements MessageGetBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageGetBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _destination; // [destination] - private final byte _bitfield0; // [noAck] - - // Constructor - public MessageGetBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _destination = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public MessageGetBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString destination, - boolean noAck - ) - { - _ticket = ticket; - _queue = queue; - _destination = destination; - byte bitfield0 = (byte)0; - if( noAck ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getDestination() - { - return _destination; - } - public final boolean getNoAck() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _destination ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _destination ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageGet(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageGetBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "destination=" ); - buf.append( getDestination() ); - buf.append( ", " ); - buf.append( "noAck=" ); - buf.append( getNoAck() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageOffsetBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageOffsetBodyImpl.java deleted file mode 100644 index 52d907df2b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageOffsetBodyImpl.java +++ /dev/null @@ -1,111 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageOffsetBodyImpl extends AMQMethodBody_0_9 implements MessageOffsetBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageOffsetBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 530; - - // Fields declared in specification - private final long _value; // [value] - - // Constructor - public MessageOffsetBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _value = readLong( buffer ); - } - - public MessageOffsetBodyImpl( - long value - ) - { - _value = value; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getValue() - { - return _value; - } - - protected int getBodySize() - { - int size = 8; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _value ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageOffset(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageOffsetBodyImpl: "); - buf.append( "value=" ); - buf.append( getValue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageOkBodyImpl.java deleted file mode 100644 index c0477e2c13..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageOkBodyImpl extends AMQMethodBody_0_9 implements MessageOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 500; - - // Fields declared in specification - - // Constructor - public MessageOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public MessageOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageOpenBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageOpenBodyImpl.java deleted file mode 100644 index d500317bfe..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageOpenBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageOpenBodyImpl extends AMQMethodBody_0_9 implements MessageOpenBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageOpenBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 60; - - // Fields declared in specification - private final byte[] _reference; // [reference] - - // Constructor - public MessageOpenBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _reference = readBytes( buffer ); - } - - public MessageOpenBodyImpl( - byte[] reference - ) - { - _reference = reference; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getReference() - { - return _reference; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _reference ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _reference ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageOpen(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageOpenBodyImpl: "); - buf.append( "reference=" ); - buf.append( getReference() == null ? "null" : java.util.Arrays.toString( getReference() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageQosBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageQosBodyImpl.java deleted file mode 100644 index ce4b655131..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageQosBodyImpl.java +++ /dev/null @@ -1,140 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageQosBodyImpl extends AMQMethodBody_0_9 implements MessageQosBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageQosBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 110; - - // Fields declared in specification - private final long _prefetchSize; // [prefetchSize] - private final int _prefetchCount; // [prefetchCount] - private final byte _bitfield0; // [global] - - // Constructor - public MessageQosBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _prefetchSize = readUnsignedInteger( buffer ); - _prefetchCount = readUnsignedShort( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public MessageQosBodyImpl( - long prefetchSize, - int prefetchCount, - boolean global - ) - { - _prefetchSize = prefetchSize; - _prefetchCount = prefetchCount; - byte bitfield0 = (byte)0; - if( global ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getPrefetchSize() - { - return _prefetchSize; - } - public final int getPrefetchCount() - { - return _prefetchCount; - } - public final boolean getGlobal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 7; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _prefetchSize ); - writeUnsignedShort( buffer, _prefetchCount ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageQos(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageQosBodyImpl: "); - buf.append( "prefetchSize=" ); - buf.append( getPrefetchSize() ); - buf.append( ", " ); - buf.append( "prefetchCount=" ); - buf.append( getPrefetchCount() ); - buf.append( ", " ); - buf.append( "global=" ); - buf.append( getGlobal() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageRecoverBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageRecoverBodyImpl.java deleted file mode 100644 index 7fac0d9a46..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageRecoverBodyImpl.java +++ /dev/null @@ -1,116 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageRecoverBodyImpl extends AMQMethodBody_0_9 implements MessageRecoverBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageRecoverBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 50; - - // Fields declared in specification - private final byte _bitfield0; // [requeue] - - // Constructor - public MessageRecoverBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _bitfield0 = readBitfield( buffer ); - } - - public MessageRecoverBodyImpl( - boolean requeue - ) - { - byte bitfield0 = (byte)0; - if( requeue ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final boolean getRequeue() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageRecover(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageRecoverBodyImpl: "); - buf.append( "requeue=" ); - buf.append( getRequeue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageRejectBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageRejectBodyImpl.java deleted file mode 100644 index eb15a960c5..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageRejectBodyImpl.java +++ /dev/null @@ -1,124 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageRejectBodyImpl extends AMQMethodBody_0_9 implements MessageRejectBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageRejectBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 520; - - // Fields declared in specification - private final int _code; // [code] - private final AMQShortString _text; // [text] - - // Constructor - public MessageRejectBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _code = readUnsignedShort( buffer ); - _text = readAMQShortString( buffer ); - } - - public MessageRejectBodyImpl( - int code, - AMQShortString text - ) - { - _code = code; - _text = text; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getCode() - { - return _code; - } - public final AMQShortString getText() - { - return _text; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _text ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _code ); - writeAMQShortString( buffer, _text ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageReject(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageRejectBodyImpl: "); - buf.append( "code=" ); - buf.append( getCode() ); - buf.append( ", " ); - buf.append( "text=" ); - buf.append( getText() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageResumeBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageResumeBodyImpl.java deleted file mode 100644 index b8bcb2f309..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageResumeBodyImpl.java +++ /dev/null @@ -1,125 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageResumeBodyImpl extends AMQMethodBody_0_9 implements MessageResumeBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageResumeBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 100; - - // Fields declared in specification - private final byte[] _reference; // [reference] - private final AMQShortString _identifier; // [identifier] - - // Constructor - public MessageResumeBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _reference = readBytes( buffer ); - _identifier = readAMQShortString( buffer ); - } - - public MessageResumeBodyImpl( - byte[] reference, - AMQShortString identifier - ) - { - _reference = reference; - _identifier = identifier; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getReference() - { - return _reference; - } - public final AMQShortString getIdentifier() - { - return _identifier; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _reference ); - size += getSizeOf( _identifier ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _reference ); - writeAMQShortString( buffer, _identifier ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageResume(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageResumeBodyImpl: "); - buf.append( "reference=" ); - buf.append( getReference() == null ? "null" : java.util.Arrays.toString( getReference() ) ); - buf.append( ", " ); - buf.append( "identifier=" ); - buf.append( getIdentifier() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageTransferBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageTransferBodyImpl.java deleted file mode 100644 index 947334812c..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MessageTransferBodyImpl.java +++ /dev/null @@ -1,384 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class MessageTransferBodyImpl extends AMQMethodBody_0_9 implements MessageTransferBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new MessageTransferBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _destination; // [destination] - private final byte _bitfield0; // [redelivered, immediate] - private final long _ttl; // [ttl] - private final short _priority; // [priority] - private final long _timestamp; // [timestamp] - private final short _deliveryMode; // [deliveryMode] - private final long _expiration; // [expiration] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final AMQShortString _messageId; // [messageId] - private final AMQShortString _correlationId; // [correlationId] - private final AMQShortString _replyTo; // [replyTo] - private final AMQShortString _contentType; // [contentType] - private final AMQShortString _contentEncoding; // [contentEncoding] - private final AMQShortString _userId; // [userId] - private final AMQShortString _appId; // [appId] - private final AMQShortString _transactionId; // [transactionId] - private final byte[] _securityToken; // [securityToken] - private final FieldTable _applicationHeaders; // [applicationHeaders] - private final Content _body; // [body] - - // Constructor - public MessageTransferBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _destination = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _ttl = readLong( buffer ); - _priority = readUnsignedByte( buffer ); - _timestamp = readTimestamp( buffer ); - _deliveryMode = readUnsignedByte( buffer ); - _expiration = readTimestamp( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _messageId = readAMQShortString( buffer ); - _correlationId = readAMQShortString( buffer ); - _replyTo = readAMQShortString( buffer ); - _contentType = readAMQShortString( buffer ); - _contentEncoding = readAMQShortString( buffer ); - _userId = readAMQShortString( buffer ); - _appId = readAMQShortString( buffer ); - _transactionId = readAMQShortString( buffer ); - _securityToken = readBytes( buffer ); - _applicationHeaders = readFieldTable( buffer ); - _body = readContent( buffer ); - } - - public MessageTransferBodyImpl( - int ticket, - AMQShortString destination, - boolean redelivered, - boolean immediate, - long ttl, - short priority, - long timestamp, - short deliveryMode, - long expiration, - AMQShortString exchange, - AMQShortString routingKey, - AMQShortString messageId, - AMQShortString correlationId, - AMQShortString replyTo, - AMQShortString contentType, - AMQShortString contentEncoding, - AMQShortString userId, - AMQShortString appId, - AMQShortString transactionId, - byte[] securityToken, - FieldTable applicationHeaders, - Content body - ) - { - _ticket = ticket; - _destination = destination; - byte bitfield0 = (byte)0; - if( redelivered ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( immediate ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - _bitfield0 = bitfield0; - _ttl = ttl; - _priority = priority; - _timestamp = timestamp; - _deliveryMode = deliveryMode; - _expiration = expiration; - _exchange = exchange; - _routingKey = routingKey; - _messageId = messageId; - _correlationId = correlationId; - _replyTo = replyTo; - _contentType = contentType; - _contentEncoding = contentEncoding; - _userId = userId; - _appId = appId; - _transactionId = transactionId; - _securityToken = securityToken; - _applicationHeaders = applicationHeaders; - _body = body; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getDestination() - { - return _destination; - } - public final boolean getRedelivered() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getImmediate() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final long getTtl() - { - return _ttl; - } - public final short getPriority() - { - return _priority; - } - public final long getTimestamp() - { - return _timestamp; - } - public final short getDeliveryMode() - { - return _deliveryMode; - } - public final long getExpiration() - { - return _expiration; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final AMQShortString getMessageId() - { - return _messageId; - } - public final AMQShortString getCorrelationId() - { - return _correlationId; - } - public final AMQShortString getReplyTo() - { - return _replyTo; - } - public final AMQShortString getContentType() - { - return _contentType; - } - public final AMQShortString getContentEncoding() - { - return _contentEncoding; - } - public final AMQShortString getUserId() - { - return _userId; - } - public final AMQShortString getAppId() - { - return _appId; - } - public final AMQShortString getTransactionId() - { - return _transactionId; - } - public final byte[] getSecurityToken() - { - return _securityToken; - } - public final FieldTable getApplicationHeaders() - { - return _applicationHeaders; - } - public final Content getBody() - { - return _body; - } - - protected int getBodySize() - { - int size = 29; - size += getSizeOf( _destination ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - size += getSizeOf( _messageId ); - size += getSizeOf( _correlationId ); - size += getSizeOf( _replyTo ); - size += getSizeOf( _contentType ); - size += getSizeOf( _contentEncoding ); - size += getSizeOf( _userId ); - size += getSizeOf( _appId ); - size += getSizeOf( _transactionId ); - size += getSizeOf( _securityToken ); - size += getSizeOf( _applicationHeaders ); - size += getSizeOf( _body ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _destination ); - writeBitfield( buffer, _bitfield0 ); - writeLong( buffer, _ttl ); - writeUnsignedByte( buffer, _priority ); - writeTimestamp( buffer, _timestamp ); - writeUnsignedByte( buffer, _deliveryMode ); - writeTimestamp( buffer, _expiration ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeAMQShortString( buffer, _messageId ); - writeAMQShortString( buffer, _correlationId ); - writeAMQShortString( buffer, _replyTo ); - writeAMQShortString( buffer, _contentType ); - writeAMQShortString( buffer, _contentEncoding ); - writeAMQShortString( buffer, _userId ); - writeAMQShortString( buffer, _appId ); - writeAMQShortString( buffer, _transactionId ); - writeBytes( buffer, _securityToken ); - writeFieldTable( buffer, _applicationHeaders ); - writeContent( buffer, _body ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchMessageTransfer(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[MessageTransferBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "destination=" ); - buf.append( getDestination() ); - buf.append( ", " ); - buf.append( "redelivered=" ); - buf.append( getRedelivered() ); - buf.append( ", " ); - buf.append( "immediate=" ); - buf.append( getImmediate() ); - buf.append( ", " ); - buf.append( "ttl=" ); - buf.append( getTtl() ); - buf.append( ", " ); - buf.append( "priority=" ); - buf.append( getPriority() ); - buf.append( ", " ); - buf.append( "timestamp=" ); - buf.append( getTimestamp() ); - buf.append( ", " ); - buf.append( "deliveryMode=" ); - buf.append( getDeliveryMode() ); - buf.append( ", " ); - buf.append( "expiration=" ); - buf.append( getExpiration() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "messageId=" ); - buf.append( getMessageId() ); - buf.append( ", " ); - buf.append( "correlationId=" ); - buf.append( getCorrelationId() ); - buf.append( ", " ); - buf.append( "replyTo=" ); - buf.append( getReplyTo() ); - buf.append( ", " ); - buf.append( "contentType=" ); - buf.append( getContentType() ); - buf.append( ", " ); - buf.append( "contentEncoding=" ); - buf.append( getContentEncoding() ); - buf.append( ", " ); - buf.append( "userId=" ); - buf.append( getUserId() ); - buf.append( ", " ); - buf.append( "appId=" ); - buf.append( getAppId() ); - buf.append( ", " ); - buf.append( "transactionId=" ); - buf.append( getTransactionId() ); - buf.append( ", " ); - buf.append( "securityToken=" ); - buf.append( getSecurityToken() == null ? "null" : java.util.Arrays.toString( getSecurityToken() ) ); - buf.append( ", " ); - buf.append( "applicationHeaders=" ); - buf.append( getApplicationHeaders() ); - buf.append( ", " ); - buf.append( "body=" ); - buf.append( getBody() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MethodConverter_0_9.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MethodConverter_0_9.java deleted file mode 100644 index 6456eacab1..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MethodConverter_0_9.java +++ /dev/null @@ -1,67 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.BasicPublishBody; -import org.apache.qpid.framing.abstraction.AbstractMethodConverter; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; -import org.apache.qpid.framing.abstraction.MessagePublishInfoImpl; -import org.apache.qpid.framing.abstraction.ProtocolVersionMethodConverter; - - -public class MethodConverter_0_9 extends AbstractMethodConverter implements ProtocolVersionMethodConverter -{ - - public MethodConverter_0_9() - { - super((byte)0,(byte)9); - } - - - public MessagePublishInfo convertToInfo(AMQMethodBody methodBody) - { - final BasicPublishBody publishBody = ((BasicPublishBody) methodBody); - - final AMQShortString exchange = publishBody.getExchange(); - final AMQShortString routingKey = publishBody.getRoutingKey(); - - return new MessagePublishInfoImpl(exchange, - publishBody.getImmediate(), - publishBody.getMandatory(), - routingKey); - - } - - public AMQMethodBody convertToBody(MessagePublishInfo info) - { - - return new BasicPublishBodyImpl(0, - info.getExchange(), - info.getRoutingKey(), - info.isMandatory(), - info.isImmediate()) ; - - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MethodDispatcher_0_9.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MethodDispatcher_0_9.java deleted file mode 100644 index 00c81e1180..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MethodDispatcher_0_9.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.framing.*; - -public interface MethodDispatcher_0_9 - extends MethodDispatcher, - ServerMethodDispatcher_0_9, - ClientMethodDispatcher_0_9 -{ - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MethodRegistry_0_9.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MethodRegistry_0_9.java deleted file mode 100644 index f0e317fc1e..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/MethodRegistry_0_9.java +++ /dev/null @@ -1,1591 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.framing.*; -import org.apache.qpid.protocol.AMQConstant; - - -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import java.io.IOException; - -import org.apache.qpid.framing.abstraction.ProtocolVersionMethodConverter; -import org.apache.qpid.codec.MarkableDataInput; - - -public class MethodRegistry_0_9 extends MethodRegistry -{ - - private static final Logger _log = LoggerFactory.getLogger(MethodRegistry.class); - - private ProtocolVersionMethodConverter _protocolVersionConverter = new MethodConverter_0_9(); - - private final AMQMethodBodyInstanceFactory[][] _factories = new AMQMethodBodyInstanceFactory[121][]; - - public MethodRegistry_0_9() - { - this(new ProtocolVersion((byte)0,(byte)9)); - } - - public MethodRegistry_0_9(ProtocolVersion pv) - { - super(pv); - - - - // Register method body instance factories for the Connection class. - - _factories[10] = new AMQMethodBodyInstanceFactory[52]; - - _factories[10][10] = ConnectionStartBodyImpl.getFactory(); - _factories[10][11] = ConnectionStartOkBodyImpl.getFactory(); - _factories[10][20] = ConnectionSecureBodyImpl.getFactory(); - _factories[10][21] = ConnectionSecureOkBodyImpl.getFactory(); - _factories[10][30] = ConnectionTuneBodyImpl.getFactory(); - _factories[10][31] = ConnectionTuneOkBodyImpl.getFactory(); - _factories[10][40] = ConnectionOpenBodyImpl.getFactory(); - _factories[10][41] = ConnectionOpenOkBodyImpl.getFactory(); - _factories[10][42] = ConnectionRedirectBodyImpl.getFactory(); - _factories[10][50] = ConnectionCloseBodyImpl.getFactory(); - _factories[10][51] = ConnectionCloseOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Channel class. - - _factories[20] = new AMQMethodBodyInstanceFactory[81]; - - _factories[20][10] = ChannelOpenBodyImpl.getFactory(); - _factories[20][11] = ChannelOpenOkBodyImpl.getFactory(); - _factories[20][20] = ChannelFlowBodyImpl.getFactory(); - _factories[20][21] = ChannelFlowOkBodyImpl.getFactory(); - _factories[20][40] = ChannelCloseBodyImpl.getFactory(); - _factories[20][41] = ChannelCloseOkBodyImpl.getFactory(); - _factories[20][50] = ChannelResumeBodyImpl.getFactory(); - _factories[20][60] = ChannelPingBodyImpl.getFactory(); - _factories[20][70] = ChannelPongBodyImpl.getFactory(); - _factories[20][80] = ChannelOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Access class. - - _factories[30] = new AMQMethodBodyInstanceFactory[12]; - - _factories[30][10] = AccessRequestBodyImpl.getFactory(); - _factories[30][11] = AccessRequestOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Exchange class. - - _factories[40] = new AMQMethodBodyInstanceFactory[24]; - - _factories[40][10] = ExchangeDeclareBodyImpl.getFactory(); - _factories[40][11] = ExchangeDeclareOkBodyImpl.getFactory(); - _factories[40][20] = ExchangeDeleteBodyImpl.getFactory(); - _factories[40][21] = ExchangeDeleteOkBodyImpl.getFactory(); - _factories[40][22] = ExchangeBoundBodyImpl.getFactory(); - _factories[40][23] = ExchangeBoundOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Queue class. - - _factories[50] = new AMQMethodBodyInstanceFactory[52]; - - _factories[50][10] = QueueDeclareBodyImpl.getFactory(); - _factories[50][11] = QueueDeclareOkBodyImpl.getFactory(); - _factories[50][20] = QueueBindBodyImpl.getFactory(); - _factories[50][21] = QueueBindOkBodyImpl.getFactory(); - _factories[50][30] = QueuePurgeBodyImpl.getFactory(); - _factories[50][31] = QueuePurgeOkBodyImpl.getFactory(); - _factories[50][40] = QueueDeleteBodyImpl.getFactory(); - _factories[50][41] = QueueDeleteOkBodyImpl.getFactory(); - _factories[50][50] = QueueUnbindBodyImpl.getFactory(); - _factories[50][51] = QueueUnbindOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Basic class. - - _factories[60] = new AMQMethodBodyInstanceFactory[103]; - - _factories[60][10] = BasicQosBodyImpl.getFactory(); - _factories[60][11] = BasicQosOkBodyImpl.getFactory(); - _factories[60][20] = BasicConsumeBodyImpl.getFactory(); - _factories[60][21] = BasicConsumeOkBodyImpl.getFactory(); - _factories[60][30] = BasicCancelBodyImpl.getFactory(); - _factories[60][31] = BasicCancelOkBodyImpl.getFactory(); - _factories[60][40] = BasicPublishBodyImpl.getFactory(); - _factories[60][50] = BasicReturnBodyImpl.getFactory(); - _factories[60][60] = BasicDeliverBodyImpl.getFactory(); - _factories[60][70] = BasicGetBodyImpl.getFactory(); - _factories[60][71] = BasicGetOkBodyImpl.getFactory(); - _factories[60][72] = BasicGetEmptyBodyImpl.getFactory(); - _factories[60][80] = BasicAckBodyImpl.getFactory(); - _factories[60][90] = BasicRejectBodyImpl.getFactory(); - _factories[60][100] = BasicRecoverBodyImpl.getFactory(); - _factories[60][101] = BasicRecoverSyncOkBodyImpl.getFactory(); - _factories[60][102] = BasicRecoverSyncBodyImpl.getFactory(); - - - - // Register method body instance factories for the File class. - - _factories[70] = new AMQMethodBodyInstanceFactory[101]; - - _factories[70][10] = FileQosBodyImpl.getFactory(); - _factories[70][11] = FileQosOkBodyImpl.getFactory(); - _factories[70][20] = FileConsumeBodyImpl.getFactory(); - _factories[70][21] = FileConsumeOkBodyImpl.getFactory(); - _factories[70][30] = FileCancelBodyImpl.getFactory(); - _factories[70][31] = FileCancelOkBodyImpl.getFactory(); - _factories[70][40] = FileOpenBodyImpl.getFactory(); - _factories[70][41] = FileOpenOkBodyImpl.getFactory(); - _factories[70][50] = FileStageBodyImpl.getFactory(); - _factories[70][60] = FilePublishBodyImpl.getFactory(); - _factories[70][70] = FileReturnBodyImpl.getFactory(); - _factories[70][80] = FileDeliverBodyImpl.getFactory(); - _factories[70][90] = FileAckBodyImpl.getFactory(); - _factories[70][100] = FileRejectBodyImpl.getFactory(); - - - - // Register method body instance factories for the Stream class. - - _factories[80] = new AMQMethodBodyInstanceFactory[61]; - - _factories[80][10] = StreamQosBodyImpl.getFactory(); - _factories[80][11] = StreamQosOkBodyImpl.getFactory(); - _factories[80][20] = StreamConsumeBodyImpl.getFactory(); - _factories[80][21] = StreamConsumeOkBodyImpl.getFactory(); - _factories[80][30] = StreamCancelBodyImpl.getFactory(); - _factories[80][31] = StreamCancelOkBodyImpl.getFactory(); - _factories[80][40] = StreamPublishBodyImpl.getFactory(); - _factories[80][50] = StreamReturnBodyImpl.getFactory(); - _factories[80][60] = StreamDeliverBodyImpl.getFactory(); - - - - // Register method body instance factories for the Tx class. - - _factories[90] = new AMQMethodBodyInstanceFactory[32]; - - _factories[90][10] = TxSelectBodyImpl.getFactory(); - _factories[90][11] = TxSelectOkBodyImpl.getFactory(); - _factories[90][20] = TxCommitBodyImpl.getFactory(); - _factories[90][21] = TxCommitOkBodyImpl.getFactory(); - _factories[90][30] = TxRollbackBodyImpl.getFactory(); - _factories[90][31] = TxRollbackOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Dtx class. - - _factories[100] = new AMQMethodBodyInstanceFactory[22]; - - _factories[100][10] = DtxSelectBodyImpl.getFactory(); - _factories[100][11] = DtxSelectOkBodyImpl.getFactory(); - _factories[100][20] = DtxStartBodyImpl.getFactory(); - _factories[100][21] = DtxStartOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Tunnel class. - - _factories[110] = new AMQMethodBodyInstanceFactory[11]; - - _factories[110][10] = TunnelRequestBodyImpl.getFactory(); - - - - // Register method body instance factories for the Message class. - - _factories[120] = new AMQMethodBodyInstanceFactory[531]; - - _factories[120][10] = MessageTransferBodyImpl.getFactory(); - _factories[120][20] = MessageConsumeBodyImpl.getFactory(); - _factories[120][30] = MessageCancelBodyImpl.getFactory(); - _factories[120][40] = MessageGetBodyImpl.getFactory(); - _factories[120][50] = MessageRecoverBodyImpl.getFactory(); - _factories[120][60] = MessageOpenBodyImpl.getFactory(); - _factories[120][70] = MessageCloseBodyImpl.getFactory(); - _factories[120][80] = MessageAppendBodyImpl.getFactory(); - _factories[120][90] = MessageCheckpointBodyImpl.getFactory(); - _factories[120][100] = MessageResumeBodyImpl.getFactory(); - _factories[120][110] = MessageQosBodyImpl.getFactory(); - _factories[120][500] = MessageOkBodyImpl.getFactory(); - _factories[120][510] = MessageEmptyBodyImpl.getFactory(); - _factories[120][520] = MessageRejectBodyImpl.getFactory(); - _factories[120][530] = MessageOffsetBodyImpl.getFactory(); - } - - public AMQMethodBody convertToBody(MarkableDataInput in, long size) - throws AMQFrameDecodingException, IOException - { - int classId = in.readUnsignedShort(); - int methodId = in.readUnsignedShort(); - - AMQMethodBodyInstanceFactory bodyFactory; - try - { - bodyFactory = _factories[classId][methodId]; - } - catch(NullPointerException e) - { - throw new AMQFrameDecodingException(AMQConstant.COMMAND_INVALID, - "Class " + classId + " unknown in AMQP version 0-9" - + " (while trying to decode class " + classId + " method " + methodId + "."); - } - catch(IndexOutOfBoundsException e) - { - if(classId >= _factories.length) - { - throw new AMQFrameDecodingException(AMQConstant.COMMAND_INVALID, - "Class " + classId + " unknown in AMQP version 0-9" - + " (while trying to decode class " + classId + " method " + methodId + "."); - - } - else - { - throw new AMQFrameDecodingException(AMQConstant.COMMAND_INVALID, - "Method " + methodId + " unknown in AMQP version 0-9" - + " (while trying to decode class " + classId + " method " + methodId + "."); - - } - } - - if (bodyFactory == null) - { - throw new AMQFrameDecodingException(AMQConstant.COMMAND_INVALID, - "Method " + methodId + " unknown in AMQP version 0-9" - + " (while trying to decode class " + classId + " method " + methodId + "."); - } - - return bodyFactory.newInstance(in, size); - } - - public int getMaxClassId() - { - return 120; - } - - public int getMaxMethodId(int classId) - { - return _factories[classId].length - 1; - } - - - - public ConnectionStartBody createConnectionStartBody( - final short versionMajor, - final short versionMinor, - final FieldTable serverProperties, - final byte[] mechanisms, - final byte[] locales - ) - { - return new ConnectionStartBodyImpl( - versionMajor, - versionMinor, - serverProperties, - mechanisms, - locales - ); - } - - public ConnectionStartOkBody createConnectionStartOkBody( - final FieldTable clientProperties, - final AMQShortString mechanism, - final byte[] response, - final AMQShortString locale - ) - { - return new ConnectionStartOkBodyImpl( - clientProperties, - mechanism, - response, - locale - ); - } - - public ConnectionSecureBody createConnectionSecureBody( - final byte[] challenge - ) - { - return new ConnectionSecureBodyImpl( - challenge - ); - } - - public ConnectionSecureOkBody createConnectionSecureOkBody( - final byte[] response - ) - { - return new ConnectionSecureOkBodyImpl( - response - ); - } - - public ConnectionTuneBody createConnectionTuneBody( - final int channelMax, - final long frameMax, - final int heartbeat - ) - { - return new ConnectionTuneBodyImpl( - channelMax, - frameMax, - heartbeat - ); - } - - public ConnectionTuneOkBody createConnectionTuneOkBody( - final int channelMax, - final long frameMax, - final int heartbeat - ) - { - return new ConnectionTuneOkBodyImpl( - channelMax, - frameMax, - heartbeat - ); - } - - public ConnectionOpenBody createConnectionOpenBody( - final AMQShortString virtualHost, - final AMQShortString capabilities, - final boolean insist - ) - { - return new ConnectionOpenBodyImpl( - virtualHost, - capabilities, - insist - ); - } - - public ConnectionOpenOkBody createConnectionOpenOkBody( - final AMQShortString knownHosts - ) - { - return new ConnectionOpenOkBodyImpl( - knownHosts - ); - } - - public ConnectionRedirectBody createConnectionRedirectBody( - final AMQShortString host, - final AMQShortString knownHosts - ) - { - return new ConnectionRedirectBodyImpl( - host, - knownHosts - ); - } - - public ConnectionCloseBody createConnectionCloseBody( - final int replyCode, - final AMQShortString replyText, - final int classId, - final int methodId - ) - { - return new ConnectionCloseBodyImpl( - replyCode, - replyText, - classId, - methodId - ); - } - - public ConnectionCloseOkBody createConnectionCloseOkBody( - ) - { - return new ConnectionCloseOkBodyImpl( - ); - } - - - - - public ChannelOpenBody createChannelOpenBody( - final AMQShortString outOfBand - ) - { - return new ChannelOpenBodyImpl( - outOfBand - ); - } - - public ChannelOpenOkBody createChannelOpenOkBody( - final byte[] channelId - ) - { - return new ChannelOpenOkBodyImpl( - channelId - ); - } - - public ChannelFlowBody createChannelFlowBody( - final boolean active - ) - { - return new ChannelFlowBodyImpl( - active - ); - } - - public ChannelFlowOkBody createChannelFlowOkBody( - final boolean active - ) - { - return new ChannelFlowOkBodyImpl( - active - ); - } - - public ChannelCloseBody createChannelCloseBody( - final int replyCode, - final AMQShortString replyText, - final int classId, - final int methodId - ) - { - return new ChannelCloseBodyImpl( - replyCode, - replyText, - classId, - methodId - ); - } - - public ChannelCloseOkBody createChannelCloseOkBody( - ) - { - return new ChannelCloseOkBodyImpl( - ); - } - - public ChannelResumeBody createChannelResumeBody( - final byte[] channelId - ) - { - return new ChannelResumeBodyImpl( - channelId - ); - } - - public ChannelPingBody createChannelPingBody( - ) - { - return new ChannelPingBodyImpl( - ); - } - - public ChannelPongBody createChannelPongBody( - ) - { - return new ChannelPongBodyImpl( - ); - } - - public ChannelOkBody createChannelOkBody( - ) - { - return new ChannelOkBodyImpl( - ); - } - - - - - public AccessRequestBody createAccessRequestBody( - final AMQShortString realm, - final boolean exclusive, - final boolean passive, - final boolean active, - final boolean write, - final boolean read - ) - { - return new AccessRequestBodyImpl( - realm, - exclusive, - passive, - active, - write, - read - ); - } - - public AccessRequestOkBody createAccessRequestOkBody( - final int ticket - ) - { - return new AccessRequestOkBodyImpl( - ticket - ); - } - - - - - public ExchangeDeclareBody createExchangeDeclareBody( - final int ticket, - final AMQShortString exchange, - final AMQShortString type, - final boolean passive, - final boolean durable, - final boolean autoDelete, - final boolean internal, - final boolean nowait, - final FieldTable arguments - ) - { - return new ExchangeDeclareBodyImpl( - ticket, - exchange, - type, - passive, - durable, - autoDelete, - internal, - nowait, - arguments - ); - } - - public ExchangeDeclareOkBody createExchangeDeclareOkBody( - ) - { - return new ExchangeDeclareOkBodyImpl( - ); - } - - public ExchangeDeleteBody createExchangeDeleteBody( - final int ticket, - final AMQShortString exchange, - final boolean ifUnused, - final boolean nowait - ) - { - return new ExchangeDeleteBodyImpl( - ticket, - exchange, - ifUnused, - nowait - ); - } - - public ExchangeDeleteOkBody createExchangeDeleteOkBody( - ) - { - return new ExchangeDeleteOkBodyImpl( - ); - } - - public ExchangeBoundBody createExchangeBoundBody( - final AMQShortString exchange, - final AMQShortString routingKey, - final AMQShortString queue - ) - { - return new ExchangeBoundBodyImpl( - exchange, - routingKey, - queue - ); - } - - public ExchangeBoundOkBody createExchangeBoundOkBody( - final int replyCode, - final AMQShortString replyText - ) - { - return new ExchangeBoundOkBodyImpl( - replyCode, - replyText - ); - } - - - - - public QueueDeclareBody createQueueDeclareBody( - final int ticket, - final AMQShortString queue, - final boolean passive, - final boolean durable, - final boolean exclusive, - final boolean autoDelete, - final boolean nowait, - final FieldTable arguments - ) - { - return new QueueDeclareBodyImpl( - ticket, - queue, - passive, - durable, - exclusive, - autoDelete, - nowait, - arguments - ); - } - - public QueueDeclareOkBody createQueueDeclareOkBody( - final AMQShortString queue, - final long messageCount, - final long consumerCount - ) - { - return new QueueDeclareOkBodyImpl( - queue, - messageCount, - consumerCount - ); - } - - public QueueBindBody createQueueBindBody( - final int ticket, - final AMQShortString queue, - final AMQShortString exchange, - final AMQShortString routingKey, - final boolean nowait, - final FieldTable arguments - ) - { - return new QueueBindBodyImpl( - ticket, - queue, - exchange, - routingKey, - nowait, - arguments - ); - } - - public QueueBindOkBody createQueueBindOkBody( - ) - { - return new QueueBindOkBodyImpl( - ); - } - - public QueuePurgeBody createQueuePurgeBody( - final int ticket, - final AMQShortString queue, - final boolean nowait - ) - { - return new QueuePurgeBodyImpl( - ticket, - queue, - nowait - ); - } - - public QueuePurgeOkBody createQueuePurgeOkBody( - final long messageCount - ) - { - return new QueuePurgeOkBodyImpl( - messageCount - ); - } - - public QueueDeleteBody createQueueDeleteBody( - final int ticket, - final AMQShortString queue, - final boolean ifUnused, - final boolean ifEmpty, - final boolean nowait - ) - { - return new QueueDeleteBodyImpl( - ticket, - queue, - ifUnused, - ifEmpty, - nowait - ); - } - - public QueueDeleteOkBody createQueueDeleteOkBody( - final long messageCount - ) - { - return new QueueDeleteOkBodyImpl( - messageCount - ); - } - - public QueueUnbindBody createQueueUnbindBody( - final int ticket, - final AMQShortString queue, - final AMQShortString exchange, - final AMQShortString routingKey, - final FieldTable arguments - ) - { - return new QueueUnbindBodyImpl( - ticket, - queue, - exchange, - routingKey, - arguments - ); - } - - public QueueUnbindOkBody createQueueUnbindOkBody( - ) - { - return new QueueUnbindOkBodyImpl( - ); - } - - - - - public BasicQosBody createBasicQosBody( - final long prefetchSize, - final int prefetchCount, - final boolean global - ) - { - return new BasicQosBodyImpl( - prefetchSize, - prefetchCount, - global - ); - } - - public BasicQosOkBody createBasicQosOkBody( - ) - { - return new BasicQosOkBodyImpl( - ); - } - - public BasicConsumeBody createBasicConsumeBody( - final int ticket, - final AMQShortString queue, - final AMQShortString consumerTag, - final boolean noLocal, - final boolean noAck, - final boolean exclusive, - final boolean nowait, - final FieldTable arguments - ) - { - return new BasicConsumeBodyImpl( - ticket, - queue, - consumerTag, - noLocal, - noAck, - exclusive, - nowait, - arguments - ); - } - - public BasicConsumeOkBody createBasicConsumeOkBody( - final AMQShortString consumerTag - ) - { - return new BasicConsumeOkBodyImpl( - consumerTag - ); - } - - public BasicCancelBody createBasicCancelBody( - final AMQShortString consumerTag, - final boolean nowait - ) - { - return new BasicCancelBodyImpl( - consumerTag, - nowait - ); - } - - public BasicCancelOkBody createBasicCancelOkBody( - final AMQShortString consumerTag - ) - { - return new BasicCancelOkBodyImpl( - consumerTag - ); - } - - public BasicPublishBody createBasicPublishBody( - final int ticket, - final AMQShortString exchange, - final AMQShortString routingKey, - final boolean mandatory, - final boolean immediate - ) - { - return new BasicPublishBodyImpl( - ticket, - exchange, - routingKey, - mandatory, - immediate - ); - } - - public BasicReturnBody createBasicReturnBody( - final int replyCode, - final AMQShortString replyText, - final AMQShortString exchange, - final AMQShortString routingKey - ) - { - return new BasicReturnBodyImpl( - replyCode, - replyText, - exchange, - routingKey - ); - } - - public BasicDeliverBody createBasicDeliverBody( - final AMQShortString consumerTag, - final long deliveryTag, - final boolean redelivered, - final AMQShortString exchange, - final AMQShortString routingKey - ) - { - return new BasicDeliverBodyImpl( - consumerTag, - deliveryTag, - redelivered, - exchange, - routingKey - ); - } - - public BasicGetBody createBasicGetBody( - final int ticket, - final AMQShortString queue, - final boolean noAck - ) - { - return new BasicGetBodyImpl( - ticket, - queue, - noAck - ); - } - - public BasicGetOkBody createBasicGetOkBody( - final long deliveryTag, - final boolean redelivered, - final AMQShortString exchange, - final AMQShortString routingKey, - final long messageCount - ) - { - return new BasicGetOkBodyImpl( - deliveryTag, - redelivered, - exchange, - routingKey, - messageCount - ); - } - - public BasicGetEmptyBody createBasicGetEmptyBody( - final AMQShortString clusterId - ) - { - return new BasicGetEmptyBodyImpl( - clusterId - ); - } - - public BasicAckBody createBasicAckBody( - final long deliveryTag, - final boolean multiple - ) - { - return new BasicAckBodyImpl( - deliveryTag, - multiple - ); - } - - public BasicRejectBody createBasicRejectBody( - final long deliveryTag, - final boolean requeue - ) - { - return new BasicRejectBodyImpl( - deliveryTag, - requeue - ); - } - - public BasicRecoverBody createBasicRecoverBody( - final boolean requeue - ) - { - return new BasicRecoverBodyImpl( - requeue - ); - } - - public BasicRecoverSyncOkBody createBasicRecoverSyncOkBody( - ) - { - return new BasicRecoverSyncOkBodyImpl( - ); - } - - public BasicRecoverSyncBody createBasicRecoverSyncBody( - final boolean requeue - ) - { - return new BasicRecoverSyncBodyImpl( - requeue - ); - } - - - - - public FileQosBody createFileQosBody( - final long prefetchSize, - final int prefetchCount, - final boolean global - ) - { - return new FileQosBodyImpl( - prefetchSize, - prefetchCount, - global - ); - } - - public FileQosOkBody createFileQosOkBody( - ) - { - return new FileQosOkBodyImpl( - ); - } - - public FileConsumeBody createFileConsumeBody( - final int ticket, - final AMQShortString queue, - final AMQShortString consumerTag, - final boolean noLocal, - final boolean noAck, - final boolean exclusive, - final boolean nowait, - final FieldTable filter - ) - { - return new FileConsumeBodyImpl( - ticket, - queue, - consumerTag, - noLocal, - noAck, - exclusive, - nowait, - filter - ); - } - - public FileConsumeOkBody createFileConsumeOkBody( - final AMQShortString consumerTag - ) - { - return new FileConsumeOkBodyImpl( - consumerTag - ); - } - - public FileCancelBody createFileCancelBody( - final AMQShortString consumerTag, - final boolean nowait - ) - { - return new FileCancelBodyImpl( - consumerTag, - nowait - ); - } - - public FileCancelOkBody createFileCancelOkBody( - final AMQShortString consumerTag - ) - { - return new FileCancelOkBodyImpl( - consumerTag - ); - } - - public FileOpenBody createFileOpenBody( - final AMQShortString identifier, - final long contentSize - ) - { - return new FileOpenBodyImpl( - identifier, - contentSize - ); - } - - public FileOpenOkBody createFileOpenOkBody( - final long stagedSize - ) - { - return new FileOpenOkBodyImpl( - stagedSize - ); - } - - public FileStageBody createFileStageBody( - ) - { - return new FileStageBodyImpl( - ); - } - - public FilePublishBody createFilePublishBody( - final int ticket, - final AMQShortString exchange, - final AMQShortString routingKey, - final boolean mandatory, - final boolean immediate, - final AMQShortString identifier - ) - { - return new FilePublishBodyImpl( - ticket, - exchange, - routingKey, - mandatory, - immediate, - identifier - ); - } - - public FileReturnBody createFileReturnBody( - final int replyCode, - final AMQShortString replyText, - final AMQShortString exchange, - final AMQShortString routingKey - ) - { - return new FileReturnBodyImpl( - replyCode, - replyText, - exchange, - routingKey - ); - } - - public FileDeliverBody createFileDeliverBody( - final AMQShortString consumerTag, - final long deliveryTag, - final boolean redelivered, - final AMQShortString exchange, - final AMQShortString routingKey, - final AMQShortString identifier - ) - { - return new FileDeliverBodyImpl( - consumerTag, - deliveryTag, - redelivered, - exchange, - routingKey, - identifier - ); - } - - public FileAckBody createFileAckBody( - final long deliveryTag, - final boolean multiple - ) - { - return new FileAckBodyImpl( - deliveryTag, - multiple - ); - } - - public FileRejectBody createFileRejectBody( - final long deliveryTag, - final boolean requeue - ) - { - return new FileRejectBodyImpl( - deliveryTag, - requeue - ); - } - - - - - public StreamQosBody createStreamQosBody( - final long prefetchSize, - final int prefetchCount, - final long consumeRate, - final boolean global - ) - { - return new StreamQosBodyImpl( - prefetchSize, - prefetchCount, - consumeRate, - global - ); - } - - public StreamQosOkBody createStreamQosOkBody( - ) - { - return new StreamQosOkBodyImpl( - ); - } - - public StreamConsumeBody createStreamConsumeBody( - final int ticket, - final AMQShortString queue, - final AMQShortString consumerTag, - final boolean noLocal, - final boolean exclusive, - final boolean nowait, - final FieldTable filter - ) - { - return new StreamConsumeBodyImpl( - ticket, - queue, - consumerTag, - noLocal, - exclusive, - nowait, - filter - ); - } - - public StreamConsumeOkBody createStreamConsumeOkBody( - final AMQShortString consumerTag - ) - { - return new StreamConsumeOkBodyImpl( - consumerTag - ); - } - - public StreamCancelBody createStreamCancelBody( - final AMQShortString consumerTag, - final boolean nowait - ) - { - return new StreamCancelBodyImpl( - consumerTag, - nowait - ); - } - - public StreamCancelOkBody createStreamCancelOkBody( - final AMQShortString consumerTag - ) - { - return new StreamCancelOkBodyImpl( - consumerTag - ); - } - - public StreamPublishBody createStreamPublishBody( - final int ticket, - final AMQShortString exchange, - final AMQShortString routingKey, - final boolean mandatory, - final boolean immediate - ) - { - return new StreamPublishBodyImpl( - ticket, - exchange, - routingKey, - mandatory, - immediate - ); - } - - public StreamReturnBody createStreamReturnBody( - final int replyCode, - final AMQShortString replyText, - final AMQShortString exchange, - final AMQShortString routingKey - ) - { - return new StreamReturnBodyImpl( - replyCode, - replyText, - exchange, - routingKey - ); - } - - public StreamDeliverBody createStreamDeliverBody( - final AMQShortString consumerTag, - final long deliveryTag, - final AMQShortString exchange, - final AMQShortString queue - ) - { - return new StreamDeliverBodyImpl( - consumerTag, - deliveryTag, - exchange, - queue - ); - } - - - - - public TxSelectBody createTxSelectBody( - ) - { - return new TxSelectBodyImpl( - ); - } - - public TxSelectOkBody createTxSelectOkBody( - ) - { - return new TxSelectOkBodyImpl( - ); - } - - public TxCommitBody createTxCommitBody( - ) - { - return new TxCommitBodyImpl( - ); - } - - public TxCommitOkBody createTxCommitOkBody( - ) - { - return new TxCommitOkBodyImpl( - ); - } - - public TxRollbackBody createTxRollbackBody( - ) - { - return new TxRollbackBodyImpl( - ); - } - - public TxRollbackOkBody createTxRollbackOkBody( - ) - { - return new TxRollbackOkBodyImpl( - ); - } - - - - - public DtxSelectBody createDtxSelectBody( - ) - { - return new DtxSelectBodyImpl( - ); - } - - public DtxSelectOkBody createDtxSelectOkBody( - ) - { - return new DtxSelectOkBodyImpl( - ); - } - - public DtxStartBody createDtxStartBody( - final AMQShortString dtxIdentifier - ) - { - return new DtxStartBodyImpl( - dtxIdentifier - ); - } - - public DtxStartOkBody createDtxStartOkBody( - ) - { - return new DtxStartOkBodyImpl( - ); - } - - - - - public TunnelRequestBody createTunnelRequestBody( - final FieldTable metaData - ) - { - return new TunnelRequestBodyImpl( - metaData - ); - } - - - - - public MessageTransferBody createMessageTransferBody( - final int ticket, - final AMQShortString destination, - final boolean redelivered, - final boolean immediate, - final long ttl, - final short priority, - final long timestamp, - final short deliveryMode, - final long expiration, - final AMQShortString exchange, - final AMQShortString routingKey, - final AMQShortString messageId, - final AMQShortString correlationId, - final AMQShortString replyTo, - final AMQShortString contentType, - final AMQShortString contentEncoding, - final AMQShortString userId, - final AMQShortString appId, - final AMQShortString transactionId, - final byte[] securityToken, - final FieldTable applicationHeaders, - final Content body - ) - { - return new MessageTransferBodyImpl( - ticket, - destination, - redelivered, - immediate, - ttl, - priority, - timestamp, - deliveryMode, - expiration, - exchange, - routingKey, - messageId, - correlationId, - replyTo, - contentType, - contentEncoding, - userId, - appId, - transactionId, - securityToken, - applicationHeaders, - body - ); - } - - public MessageConsumeBody createMessageConsumeBody( - final int ticket, - final AMQShortString queue, - final AMQShortString destination, - final boolean noLocal, - final boolean noAck, - final boolean exclusive, - final FieldTable filter - ) - { - return new MessageConsumeBodyImpl( - ticket, - queue, - destination, - noLocal, - noAck, - exclusive, - filter - ); - } - - public MessageCancelBody createMessageCancelBody( - final AMQShortString destination - ) - { - return new MessageCancelBodyImpl( - destination - ); - } - - public MessageGetBody createMessageGetBody( - final int ticket, - final AMQShortString queue, - final AMQShortString destination, - final boolean noAck - ) - { - return new MessageGetBodyImpl( - ticket, - queue, - destination, - noAck - ); - } - - public MessageRecoverBody createMessageRecoverBody( - final boolean requeue - ) - { - return new MessageRecoverBodyImpl( - requeue - ); - } - - public MessageOpenBody createMessageOpenBody( - final byte[] reference - ) - { - return new MessageOpenBodyImpl( - reference - ); - } - - public MessageCloseBody createMessageCloseBody( - final byte[] reference - ) - { - return new MessageCloseBodyImpl( - reference - ); - } - - public MessageAppendBody createMessageAppendBody( - final byte[] reference, - final byte[] bytes - ) - { - return new MessageAppendBodyImpl( - reference, - bytes - ); - } - - public MessageCheckpointBody createMessageCheckpointBody( - final byte[] reference, - final AMQShortString identifier - ) - { - return new MessageCheckpointBodyImpl( - reference, - identifier - ); - } - - public MessageResumeBody createMessageResumeBody( - final byte[] reference, - final AMQShortString identifier - ) - { - return new MessageResumeBodyImpl( - reference, - identifier - ); - } - - public MessageQosBody createMessageQosBody( - final long prefetchSize, - final int prefetchCount, - final boolean global - ) - { - return new MessageQosBodyImpl( - prefetchSize, - prefetchCount, - global - ); - } - - public MessageOkBody createMessageOkBody( - ) - { - return new MessageOkBodyImpl( - ); - } - - public MessageEmptyBody createMessageEmptyBody( - ) - { - return new MessageEmptyBodyImpl( - ); - } - - public MessageRejectBody createMessageRejectBody( - final int code, - final AMQShortString text - ) - { - return new MessageRejectBodyImpl( - code, - text - ); - } - - public MessageOffsetBody createMessageOffsetBody( - final long value - ) - { - return new MessageOffsetBodyImpl( - value - ); - } - - - - public ProtocolVersionMethodConverter getProtocolVersionMethodConverter() - { - return _protocolVersionConverter; - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueBindBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueBindBodyImpl.java deleted file mode 100644 index 989a6d4877..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueBindBodyImpl.java +++ /dev/null @@ -1,181 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueBindBodyImpl extends AMQMethodBody_0_9 implements QueueBindBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueBindBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final byte _bitfield0; // [nowait] - private final FieldTable _arguments; // [arguments] - - // Constructor - public QueueBindBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _arguments = readFieldTable( buffer ); - } - - public QueueBindBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString exchange, - AMQShortString routingKey, - boolean nowait, - FieldTable arguments - ) - { - _ticket = ticket; - _queue = queue; - _exchange = exchange; - _routingKey = routingKey; - byte bitfield0 = (byte)0; - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - _bitfield0 = bitfield0; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchQueueBind(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueBindBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueBindOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueBindOkBodyImpl.java deleted file mode 100644 index 1469912b2b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueBindOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueBindOkBodyImpl extends AMQMethodBody_0_9 implements QueueBindOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueBindOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 21; - - // Fields declared in specification - - // Constructor - public QueueBindOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public QueueBindOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchQueueBindOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueBindOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueDeclareBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueDeclareBodyImpl.java deleted file mode 100644 index 7b2926f32f..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueDeclareBodyImpl.java +++ /dev/null @@ -1,207 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueDeclareBodyImpl extends AMQMethodBody_0_9 implements QueueDeclareBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueDeclareBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final byte _bitfield0; // [passive, durable, exclusive, autoDelete, nowait] - private final FieldTable _arguments; // [arguments] - - // Constructor - public QueueDeclareBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _arguments = readFieldTable( buffer ); - } - - public QueueDeclareBodyImpl( - int ticket, - AMQShortString queue, - boolean passive, - boolean durable, - boolean exclusive, - boolean autoDelete, - boolean nowait, - FieldTable arguments - ) - { - _ticket = ticket; - _queue = queue; - byte bitfield0 = (byte)0; - if( passive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( durable ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( exclusive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - if( autoDelete ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 4)); - } - - _bitfield0 = bitfield0; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final boolean getPassive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getDurable() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getExclusive() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final boolean getAutoDelete() - { - return (((int)(_bitfield0)) & ( 1 << 3)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 4)) != 0; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchQueueDeclare(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueDeclareBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "passive=" ); - buf.append( getPassive() ); - buf.append( ", " ); - buf.append( "durable=" ); - buf.append( getDurable() ); - buf.append( ", " ); - buf.append( "exclusive=" ); - buf.append( getExclusive() ); - buf.append( ", " ); - buf.append( "autoDelete=" ); - buf.append( getAutoDelete() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueDeclareOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueDeclareOkBodyImpl.java deleted file mode 100644 index 1c76725d2b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueDeclareOkBodyImpl.java +++ /dev/null @@ -1,136 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueDeclareOkBodyImpl extends AMQMethodBody_0_9 implements QueueDeclareOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueDeclareOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 11; - - // Fields declared in specification - private final AMQShortString _queue; // [queue] - private final long _messageCount; // [messageCount] - private final long _consumerCount; // [consumerCount] - - // Constructor - public QueueDeclareOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _queue = readAMQShortString( buffer ); - _messageCount = readUnsignedInteger( buffer ); - _consumerCount = readUnsignedInteger( buffer ); - } - - public QueueDeclareOkBodyImpl( - AMQShortString queue, - long messageCount, - long consumerCount - ) - { - _queue = queue; - _messageCount = messageCount; - _consumerCount = consumerCount; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getQueue() - { - return _queue; - } - public final long getMessageCount() - { - return _messageCount; - } - public final long getConsumerCount() - { - return _consumerCount; - } - - protected int getBodySize() - { - int size = 8; - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _queue ); - writeUnsignedInteger( buffer, _messageCount ); - writeUnsignedInteger( buffer, _consumerCount ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchQueueDeclareOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueDeclareOkBodyImpl: "); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "messageCount=" ); - buf.append( getMessageCount() ); - buf.append( ", " ); - buf.append( "consumerCount=" ); - buf.append( getConsumerCount() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueDeleteBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueDeleteBodyImpl.java deleted file mode 100644 index ea48a1d24a..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueDeleteBodyImpl.java +++ /dev/null @@ -1,167 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueDeleteBodyImpl extends AMQMethodBody_0_9 implements QueueDeleteBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueDeleteBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final byte _bitfield0; // [ifUnused, ifEmpty, nowait] - - // Constructor - public QueueDeleteBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public QueueDeleteBodyImpl( - int ticket, - AMQShortString queue, - boolean ifUnused, - boolean ifEmpty, - boolean nowait - ) - { - _ticket = ticket; - _queue = queue; - byte bitfield0 = (byte)0; - if( ifUnused ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( ifEmpty ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final boolean getIfUnused() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getIfEmpty() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchQueueDelete(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueDeleteBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "ifUnused=" ); - buf.append( getIfUnused() ); - buf.append( ", " ); - buf.append( "ifEmpty=" ); - buf.append( getIfEmpty() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueDeleteOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueDeleteOkBodyImpl.java deleted file mode 100644 index acc7a59887..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueDeleteOkBodyImpl.java +++ /dev/null @@ -1,111 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueDeleteOkBodyImpl extends AMQMethodBody_0_9 implements QueueDeleteOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueDeleteOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 41; - - // Fields declared in specification - private final long _messageCount; // [messageCount] - - // Constructor - public QueueDeleteOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _messageCount = readUnsignedInteger( buffer ); - } - - public QueueDeleteOkBodyImpl( - long messageCount - ) - { - _messageCount = messageCount; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getMessageCount() - { - return _messageCount; - } - - protected int getBodySize() - { - int size = 4; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _messageCount ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchQueueDeleteOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueDeleteOkBodyImpl: "); - buf.append( "messageCount=" ); - buf.append( getMessageCount() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueuePurgeBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueuePurgeBodyImpl.java deleted file mode 100644 index 8a1a4e206c..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueuePurgeBodyImpl.java +++ /dev/null @@ -1,141 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueuePurgeBodyImpl extends AMQMethodBody_0_9 implements QueuePurgeBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueuePurgeBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final byte _bitfield0; // [nowait] - - // Constructor - public QueuePurgeBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public QueuePurgeBodyImpl( - int ticket, - AMQShortString queue, - boolean nowait - ) - { - _ticket = ticket; - _queue = queue; - byte bitfield0 = (byte)0; - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchQueuePurge(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueuePurgeBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueuePurgeOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueuePurgeOkBodyImpl.java deleted file mode 100644 index db50a822f6..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueuePurgeOkBodyImpl.java +++ /dev/null @@ -1,111 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueuePurgeOkBodyImpl extends AMQMethodBody_0_9 implements QueuePurgeOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueuePurgeOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final long _messageCount; // [messageCount] - - // Constructor - public QueuePurgeOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _messageCount = readUnsignedInteger( buffer ); - } - - public QueuePurgeOkBodyImpl( - long messageCount - ) - { - _messageCount = messageCount; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getMessageCount() - { - return _messageCount; - } - - protected int getBodySize() - { - int size = 4; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _messageCount ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchQueuePurgeOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueuePurgeOkBodyImpl: "); - buf.append( "messageCount=" ); - buf.append( getMessageCount() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueUnbindBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueUnbindBodyImpl.java deleted file mode 100644 index fd5bb7b953..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueUnbindBodyImpl.java +++ /dev/null @@ -1,163 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueUnbindBodyImpl extends AMQMethodBody_0_9 implements QueueUnbindBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueUnbindBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 50; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final FieldTable _arguments; // [arguments] - - // Constructor - public QueueUnbindBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _arguments = readFieldTable( buffer ); - } - - public QueueUnbindBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString exchange, - AMQShortString routingKey, - FieldTable arguments - ) - { - _ticket = ticket; - _queue = queue; - _exchange = exchange; - _routingKey = routingKey; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _queue ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchQueueUnbind(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueUnbindBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueUnbindOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueUnbindOkBodyImpl.java deleted file mode 100644 index 03544b17d6..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/QueueUnbindOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueUnbindOkBodyImpl extends AMQMethodBody_0_9 implements QueueUnbindOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueUnbindOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 51; - - // Fields declared in specification - - // Constructor - public QueueUnbindOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public QueueUnbindOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchQueueUnbindOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueUnbindOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ServerMethodDispatcher_0_9.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ServerMethodDispatcher_0_9.java deleted file mode 100644 index 4100e7a031..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/ServerMethodDispatcher_0_9.java +++ /dev/null @@ -1,105 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.*; - - -public interface ServerMethodDispatcher_0_9 extends ServerMethodDispatcher -{ - - public boolean dispatchAccessRequest(AccessRequestBody body, int channelId) throws AMQException; - public boolean dispatchBasicAck(BasicAckBody body, int channelId) throws AMQException; - public boolean dispatchBasicCancel(BasicCancelBody body, int channelId) throws AMQException; - public boolean dispatchBasicConsume(BasicConsumeBody body, int channelId) throws AMQException; - public boolean dispatchBasicGet(BasicGetBody body, int channelId) throws AMQException; - public boolean dispatchBasicPublish(BasicPublishBody body, int channelId) throws AMQException; - public boolean dispatchBasicQos(BasicQosBody body, int channelId) throws AMQException; - public boolean dispatchBasicRecover(BasicRecoverBody body, int channelId) throws AMQException; - public boolean dispatchBasicRecoverSync(BasicRecoverSyncBody body, int channelId) throws AMQException; - public boolean dispatchBasicReject(BasicRejectBody body, int channelId) throws AMQException; - public boolean dispatchChannelClose(ChannelCloseBody body, int channelId) throws AMQException; - public boolean dispatchChannelCloseOk(ChannelCloseOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelFlow(ChannelFlowBody body, int channelId) throws AMQException; - public boolean dispatchChannelFlowOk(ChannelFlowOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelOk(ChannelOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelOpen(ChannelOpenBody body, int channelId) throws AMQException; - public boolean dispatchChannelPing(ChannelPingBody body, int channelId) throws AMQException; - public boolean dispatchChannelPong(ChannelPongBody body, int channelId) throws AMQException; - public boolean dispatchChannelResume(ChannelResumeBody body, int channelId) throws AMQException; - public boolean dispatchConnectionClose(ConnectionCloseBody body, int channelId) throws AMQException; - public boolean dispatchConnectionCloseOk(ConnectionCloseOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionOpen(ConnectionOpenBody body, int channelId) throws AMQException; - public boolean dispatchConnectionSecureOk(ConnectionSecureOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionStartOk(ConnectionStartOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionTuneOk(ConnectionTuneOkBody body, int channelId) throws AMQException; - public boolean dispatchDtxSelect(DtxSelectBody body, int channelId) throws AMQException; - public boolean dispatchDtxStart(DtxStartBody body, int channelId) throws AMQException; - public boolean dispatchExchangeBound(ExchangeBoundBody body, int channelId) throws AMQException; - public boolean dispatchExchangeDeclare(ExchangeDeclareBody body, int channelId) throws AMQException; - public boolean dispatchExchangeDelete(ExchangeDeleteBody body, int channelId) throws AMQException; - public boolean dispatchFileAck(FileAckBody body, int channelId) throws AMQException; - public boolean dispatchFileCancel(FileCancelBody body, int channelId) throws AMQException; - public boolean dispatchFileConsume(FileConsumeBody body, int channelId) throws AMQException; - public boolean dispatchFileOpen(FileOpenBody body, int channelId) throws AMQException; - public boolean dispatchFileOpenOk(FileOpenOkBody body, int channelId) throws AMQException; - public boolean dispatchFilePublish(FilePublishBody body, int channelId) throws AMQException; - public boolean dispatchFileQos(FileQosBody body, int channelId) throws AMQException; - public boolean dispatchFileReject(FileRejectBody body, int channelId) throws AMQException; - public boolean dispatchFileStage(FileStageBody body, int channelId) throws AMQException; - public boolean dispatchMessageAppend(MessageAppendBody body, int channelId) throws AMQException; - public boolean dispatchMessageCancel(MessageCancelBody body, int channelId) throws AMQException; - public boolean dispatchMessageCheckpoint(MessageCheckpointBody body, int channelId) throws AMQException; - public boolean dispatchMessageClose(MessageCloseBody body, int channelId) throws AMQException; - public boolean dispatchMessageConsume(MessageConsumeBody body, int channelId) throws AMQException; - public boolean dispatchMessageEmpty(MessageEmptyBody body, int channelId) throws AMQException; - public boolean dispatchMessageGet(MessageGetBody body, int channelId) throws AMQException; - public boolean dispatchMessageOffset(MessageOffsetBody body, int channelId) throws AMQException; - public boolean dispatchMessageOk(MessageOkBody body, int channelId) throws AMQException; - public boolean dispatchMessageOpen(MessageOpenBody body, int channelId) throws AMQException; - public boolean dispatchMessageQos(MessageQosBody body, int channelId) throws AMQException; - public boolean dispatchMessageRecover(MessageRecoverBody body, int channelId) throws AMQException; - public boolean dispatchMessageReject(MessageRejectBody body, int channelId) throws AMQException; - public boolean dispatchMessageResume(MessageResumeBody body, int channelId) throws AMQException; - public boolean dispatchMessageTransfer(MessageTransferBody body, int channelId) throws AMQException; - public boolean dispatchQueueBind(QueueBindBody body, int channelId) throws AMQException; - public boolean dispatchQueueDeclare(QueueDeclareBody body, int channelId) throws AMQException; - public boolean dispatchQueueDelete(QueueDeleteBody body, int channelId) throws AMQException; - public boolean dispatchQueuePurge(QueuePurgeBody body, int channelId) throws AMQException; - public boolean dispatchQueueUnbind(QueueUnbindBody body, int channelId) throws AMQException; - public boolean dispatchStreamCancel(StreamCancelBody body, int channelId) throws AMQException; - public boolean dispatchStreamConsume(StreamConsumeBody body, int channelId) throws AMQException; - public boolean dispatchStreamPublish(StreamPublishBody body, int channelId) throws AMQException; - public boolean dispatchStreamQos(StreamQosBody body, int channelId) throws AMQException; - public boolean dispatchTunnelRequest(TunnelRequestBody body, int channelId) throws AMQException; - public boolean dispatchTxCommit(TxCommitBody body, int channelId) throws AMQException; - public boolean dispatchTxRollback(TxRollbackBody body, int channelId) throws AMQException; - public boolean dispatchTxSelect(TxSelectBody body, int channelId) throws AMQException; - -}
\ No newline at end of file diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamCancelBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamCancelBodyImpl.java deleted file mode 100644 index 81ec1102f5..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamCancelBodyImpl.java +++ /dev/null @@ -1,129 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamCancelBodyImpl extends AMQMethodBody_0_9 implements StreamCancelBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamCancelBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [nowait] - - // Constructor - public StreamCancelBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public StreamCancelBodyImpl( - AMQShortString consumerTag, - boolean nowait - ) - { - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchStreamCancel(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamCancelBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamCancelOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamCancelOkBodyImpl.java deleted file mode 100644 index ec9676d782..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamCancelOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamCancelOkBodyImpl extends AMQMethodBody_0_9 implements StreamCancelOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamCancelOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public StreamCancelOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public StreamCancelOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchStreamCancelOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamCancelOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamConsumeBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamConsumeBodyImpl.java deleted file mode 100644 index ff4712d091..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamConsumeBodyImpl.java +++ /dev/null @@ -1,194 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamConsumeBodyImpl extends AMQMethodBody_0_9 implements StreamConsumeBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamConsumeBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [noLocal, exclusive, nowait] - private final FieldTable _filter; // [filter] - - // Constructor - public StreamConsumeBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _filter = readFieldTable( buffer ); - } - - public StreamConsumeBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString consumerTag, - boolean noLocal, - boolean exclusive, - boolean nowait, - FieldTable filter - ) - { - _ticket = ticket; - _queue = queue; - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( noLocal ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( exclusive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - _bitfield0 = bitfield0; - _filter = filter; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNoLocal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getExclusive() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final FieldTable getFilter() - { - return _filter; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _consumerTag ); - size += getSizeOf( _filter ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _filter ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchStreamConsume(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamConsumeBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "noLocal=" ); - buf.append( getNoLocal() ); - buf.append( ", " ); - buf.append( "exclusive=" ); - buf.append( getExclusive() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "filter=" ); - buf.append( getFilter() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamConsumeOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamConsumeOkBodyImpl.java deleted file mode 100644 index cca83758e4..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamConsumeOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamConsumeOkBodyImpl extends AMQMethodBody_0_9 implements StreamConsumeOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamConsumeOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public StreamConsumeOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public StreamConsumeOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchStreamConsumeOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamConsumeOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamDeliverBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamDeliverBodyImpl.java deleted file mode 100644 index 87e341ee5c..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamDeliverBodyImpl.java +++ /dev/null @@ -1,150 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamDeliverBodyImpl extends AMQMethodBody_0_9 implements StreamDeliverBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamDeliverBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 60; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final long _deliveryTag; // [deliveryTag] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _queue; // [queue] - - // Constructor - public StreamDeliverBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _deliveryTag = readLong( buffer ); - _exchange = readAMQShortString( buffer ); - _queue = readAMQShortString( buffer ); - } - - public StreamDeliverBodyImpl( - AMQShortString consumerTag, - long deliveryTag, - AMQShortString exchange, - AMQShortString queue - ) - { - _consumerTag = consumerTag; - _deliveryTag = deliveryTag; - _exchange = exchange; - _queue = queue; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getQueue() - { - return _queue; - } - - protected int getBodySize() - { - int size = 8; - size += getSizeOf( _consumerTag ); - size += getSizeOf( _exchange ); - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeLong( buffer, _deliveryTag ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _queue ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchStreamDeliver(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamDeliverBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamPublishBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamPublishBodyImpl.java deleted file mode 100644 index 59161fe291..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamPublishBodyImpl.java +++ /dev/null @@ -1,167 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamPublishBodyImpl extends AMQMethodBody_0_9 implements StreamPublishBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamPublishBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final byte _bitfield0; // [mandatory, immediate] - - // Constructor - public StreamPublishBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public StreamPublishBodyImpl( - int ticket, - AMQShortString exchange, - AMQShortString routingKey, - boolean mandatory, - boolean immediate - ) - { - _ticket = ticket; - _exchange = exchange; - _routingKey = routingKey; - byte bitfield0 = (byte)0; - if( mandatory ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( immediate ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final boolean getMandatory() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getImmediate() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchStreamPublish(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamPublishBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "mandatory=" ); - buf.append( getMandatory() ); - buf.append( ", " ); - buf.append( "immediate=" ); - buf.append( getImmediate() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamQosBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamQosBodyImpl.java deleted file mode 100644 index b9413d3ef2..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamQosBodyImpl.java +++ /dev/null @@ -1,152 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamQosBodyImpl extends AMQMethodBody_0_9 implements StreamQosBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamQosBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final long _prefetchSize; // [prefetchSize] - private final int _prefetchCount; // [prefetchCount] - private final long _consumeRate; // [consumeRate] - private final byte _bitfield0; // [global] - - // Constructor - public StreamQosBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _prefetchSize = readUnsignedInteger( buffer ); - _prefetchCount = readUnsignedShort( buffer ); - _consumeRate = readUnsignedInteger( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public StreamQosBodyImpl( - long prefetchSize, - int prefetchCount, - long consumeRate, - boolean global - ) - { - _prefetchSize = prefetchSize; - _prefetchCount = prefetchCount; - _consumeRate = consumeRate; - byte bitfield0 = (byte)0; - if( global ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getPrefetchSize() - { - return _prefetchSize; - } - public final int getPrefetchCount() - { - return _prefetchCount; - } - public final long getConsumeRate() - { - return _consumeRate; - } - public final boolean getGlobal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 11; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _prefetchSize ); - writeUnsignedShort( buffer, _prefetchCount ); - writeUnsignedInteger( buffer, _consumeRate ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchStreamQos(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamQosBodyImpl: "); - buf.append( "prefetchSize=" ); - buf.append( getPrefetchSize() ); - buf.append( ", " ); - buf.append( "prefetchCount=" ); - buf.append( getPrefetchCount() ); - buf.append( ", " ); - buf.append( "consumeRate=" ); - buf.append( getConsumeRate() ); - buf.append( ", " ); - buf.append( "global=" ); - buf.append( getGlobal() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamQosOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamQosOkBodyImpl.java deleted file mode 100644 index a5119c7f6d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamQosOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamQosOkBodyImpl extends AMQMethodBody_0_9 implements StreamQosOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamQosOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public StreamQosOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public StreamQosOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchStreamQosOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamQosOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamReturnBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamReturnBodyImpl.java deleted file mode 100644 index bb60ea982e..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/StreamReturnBodyImpl.java +++ /dev/null @@ -1,150 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamReturnBodyImpl extends AMQMethodBody_0_9 implements StreamReturnBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamReturnBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 50; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - - // Constructor - public StreamReturnBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - } - - public StreamReturnBodyImpl( - int replyCode, - AMQShortString replyText, - AMQShortString exchange, - AMQShortString routingKey - ) - { - _replyCode = replyCode; - _replyText = replyText; - _exchange = exchange; - _routingKey = routingKey; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _replyText ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchStreamReturn(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamReturnBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TunnelRequestBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TunnelRequestBodyImpl.java deleted file mode 100644 index fae6e1c3b9..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TunnelRequestBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TunnelRequestBodyImpl extends AMQMethodBody_0_9 implements TunnelRequestBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TunnelRequestBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 110; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final FieldTable _metaData; // [metaData] - - // Constructor - public TunnelRequestBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _metaData = readFieldTable( buffer ); - } - - public TunnelRequestBodyImpl( - FieldTable metaData - ) - { - _metaData = metaData; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final FieldTable getMetaData() - { - return _metaData; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _metaData ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeFieldTable( buffer, _metaData ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchTunnelRequest(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TunnelRequestBodyImpl: "); - buf.append( "metaData=" ); - buf.append( getMetaData() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxCommitBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxCommitBodyImpl.java deleted file mode 100644 index 9663cc86f5..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxCommitBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxCommitBodyImpl extends AMQMethodBody_0_9 implements TxCommitBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxCommitBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 20; - - // Fields declared in specification - - // Constructor - public TxCommitBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxCommitBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchTxCommit(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxCommitBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxCommitOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxCommitOkBodyImpl.java deleted file mode 100644 index fa009903b9..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxCommitOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxCommitOkBodyImpl extends AMQMethodBody_0_9 implements TxCommitOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxCommitOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 21; - - // Fields declared in specification - - // Constructor - public TxCommitOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxCommitOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchTxCommitOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxCommitOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxRollbackBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxRollbackBodyImpl.java deleted file mode 100644 index c143c34081..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxRollbackBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxRollbackBodyImpl extends AMQMethodBody_0_9 implements TxRollbackBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxRollbackBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 30; - - // Fields declared in specification - - // Constructor - public TxRollbackBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxRollbackBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchTxRollback(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxRollbackBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxRollbackOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxRollbackOkBodyImpl.java deleted file mode 100644 index a5238b8804..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxRollbackOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxRollbackOkBodyImpl extends AMQMethodBody_0_9 implements TxRollbackOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxRollbackOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 31; - - // Fields declared in specification - - // Constructor - public TxRollbackOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxRollbackOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchTxRollbackOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxRollbackOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxSelectBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxSelectBodyImpl.java deleted file mode 100644 index 9a43987fa2..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxSelectBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxSelectBodyImpl extends AMQMethodBody_0_9 implements TxSelectBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxSelectBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 10; - - // Fields declared in specification - - // Constructor - public TxSelectBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxSelectBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchTxSelect(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxSelectBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxSelectOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxSelectOkBodyImpl.java deleted file mode 100644 index c06bf4c501..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_9/TxSelectOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-9 - */ - -package org.apache.qpid.framing.amqp_0_9; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxSelectOkBodyImpl extends AMQMethodBody_0_9 implements TxSelectOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxSelectOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public TxSelectOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxSelectOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_9)dispatcher).dispatchTxSelectOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxSelectOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/AMQMethodBody_0_91.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/AMQMethodBody_0_91.java deleted file mode 100644 index 60b8a7e1a6..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/AMQMethodBody_0_91.java +++ /dev/null @@ -1,37 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -package org.apache.qpid.framing.amqp_0_91; - -public abstract class AMQMethodBody_0_91 extends org.apache.qpid.framing.AMQMethodBodyImpl -{ - - public byte getMajor() - { - return 0; - } - - public byte getMinor() - { - return 91; - } - -}
\ No newline at end of file diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicAckBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicAckBodyImpl.java deleted file mode 100644 index 059ae8fab8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicAckBodyImpl.java +++ /dev/null @@ -1,128 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicAckBodyImpl extends AMQMethodBody_0_91 implements BasicAckBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicAckBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 80; - - // Fields declared in specification - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [multiple] - - // Constructor - public BasicAckBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicAckBodyImpl( - long deliveryTag, - boolean multiple - ) - { - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( multiple ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getMultiple() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 9; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicAck(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicAckBodyImpl: "); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "multiple=" ); - buf.append( getMultiple() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicCancelBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicCancelBodyImpl.java deleted file mode 100644 index 08a07960ac..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicCancelBodyImpl.java +++ /dev/null @@ -1,129 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicCancelBodyImpl extends AMQMethodBody_0_91 implements BasicCancelBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicCancelBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [nowait] - - // Constructor - public BasicCancelBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicCancelBodyImpl( - AMQShortString consumerTag, - boolean nowait - ) - { - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicCancel(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicCancelBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicCancelOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicCancelOkBodyImpl.java deleted file mode 100644 index 380fa70a18..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicCancelOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicCancelOkBodyImpl extends AMQMethodBody_0_91 implements BasicCancelOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicCancelOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public BasicCancelOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public BasicCancelOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicCancelOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicCancelOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicConsumeBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicConsumeBodyImpl.java deleted file mode 100644 index b299c5c0d4..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicConsumeBodyImpl.java +++ /dev/null @@ -1,207 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicConsumeBodyImpl extends AMQMethodBody_0_91 implements BasicConsumeBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicConsumeBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [noLocal, noAck, exclusive, nowait] - private final FieldTable _arguments; // [arguments] - - // Constructor - public BasicConsumeBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _arguments = readFieldTable( buffer ); - } - - public BasicConsumeBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString consumerTag, - boolean noLocal, - boolean noAck, - boolean exclusive, - boolean nowait, - FieldTable arguments - ) - { - _ticket = ticket; - _queue = queue; - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( noLocal ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( noAck ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( exclusive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); - } - - _bitfield0 = bitfield0; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNoLocal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getNoAck() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getExclusive() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 3)) != 0; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _consumerTag ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicConsume(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicConsumeBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "noLocal=" ); - buf.append( getNoLocal() ); - buf.append( ", " ); - buf.append( "noAck=" ); - buf.append( getNoAck() ); - buf.append( ", " ); - buf.append( "exclusive=" ); - buf.append( getExclusive() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicConsumeOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicConsumeOkBodyImpl.java deleted file mode 100644 index 2241370c75..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicConsumeOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicConsumeOkBodyImpl extends AMQMethodBody_0_91 implements BasicConsumeOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicConsumeOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public BasicConsumeOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public BasicConsumeOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicConsumeOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicConsumeOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicDeliverBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicDeliverBodyImpl.java deleted file mode 100644 index a1a9bf6113..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicDeliverBodyImpl.java +++ /dev/null @@ -1,168 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicDeliverBodyImpl extends AMQMethodBody_0_91 implements BasicDeliverBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicDeliverBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 60; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [redelivered] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - - // Constructor - public BasicDeliverBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - } - - public BasicDeliverBodyImpl( - AMQShortString consumerTag, - long deliveryTag, - boolean redelivered, - AMQShortString exchange, - AMQShortString routingKey - ) - { - _consumerTag = consumerTag; - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( redelivered ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - _bitfield0 = bitfield0; - _exchange = exchange; - _routingKey = routingKey; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getRedelivered() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - - protected int getBodySize() - { - int size = 9; - size += getSizeOf( _consumerTag ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicDeliver(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicDeliverBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "redelivered=" ); - buf.append( getRedelivered() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicGetBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicGetBodyImpl.java deleted file mode 100644 index 2f9ca99673..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicGetBodyImpl.java +++ /dev/null @@ -1,141 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicGetBodyImpl extends AMQMethodBody_0_91 implements BasicGetBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicGetBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 70; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final byte _bitfield0; // [noAck] - - // Constructor - public BasicGetBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicGetBodyImpl( - int ticket, - AMQShortString queue, - boolean noAck - ) - { - _ticket = ticket; - _queue = queue; - byte bitfield0 = (byte)0; - if( noAck ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final boolean getNoAck() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicGet(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicGetBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "noAck=" ); - buf.append( getNoAck() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicGetEmptyBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicGetEmptyBodyImpl.java deleted file mode 100644 index 2f40867d71..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicGetEmptyBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicGetEmptyBodyImpl extends AMQMethodBody_0_91 implements BasicGetEmptyBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicGetEmptyBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 72; - - // Fields declared in specification - private final AMQShortString _clusterId; // [clusterId] - - // Constructor - public BasicGetEmptyBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _clusterId = readAMQShortString( buffer ); - } - - public BasicGetEmptyBodyImpl( - AMQShortString clusterId - ) - { - _clusterId = clusterId; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getClusterId() - { - return _clusterId; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _clusterId ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _clusterId ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicGetEmpty(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicGetEmptyBodyImpl: "); - buf.append( "clusterId=" ); - buf.append( getClusterId() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicGetOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicGetOkBodyImpl.java deleted file mode 100644 index 9666f447f1..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicGetOkBodyImpl.java +++ /dev/null @@ -1,167 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicGetOkBodyImpl extends AMQMethodBody_0_91 implements BasicGetOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicGetOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 71; - - // Fields declared in specification - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [redelivered] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final long _messageCount; // [messageCount] - - // Constructor - public BasicGetOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _messageCount = readUnsignedInteger( buffer ); - } - - public BasicGetOkBodyImpl( - long deliveryTag, - boolean redelivered, - AMQShortString exchange, - AMQShortString routingKey, - long messageCount - ) - { - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( redelivered ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - _bitfield0 = bitfield0; - _exchange = exchange; - _routingKey = routingKey; - _messageCount = messageCount; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getRedelivered() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final long getMessageCount() - { - return _messageCount; - } - - protected int getBodySize() - { - int size = 13; - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeUnsignedInteger( buffer, _messageCount ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicGetOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicGetOkBodyImpl: "); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "redelivered=" ); - buf.append( getRedelivered() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "messageCount=" ); - buf.append( getMessageCount() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicPublishBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicPublishBodyImpl.java deleted file mode 100644 index b347420128..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicPublishBodyImpl.java +++ /dev/null @@ -1,167 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicPublishBodyImpl extends AMQMethodBody_0_91 implements BasicPublishBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicPublishBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final byte _bitfield0; // [mandatory, immediate] - - // Constructor - public BasicPublishBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicPublishBodyImpl( - int ticket, - AMQShortString exchange, - AMQShortString routingKey, - boolean mandatory, - boolean immediate - ) - { - _ticket = ticket; - _exchange = exchange; - _routingKey = routingKey; - byte bitfield0 = (byte)0; - if( mandatory ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( immediate ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final boolean getMandatory() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getImmediate() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicPublish(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicPublishBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "mandatory=" ); - buf.append( getMandatory() ); - buf.append( ", " ); - buf.append( "immediate=" ); - buf.append( getImmediate() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicQosBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicQosBodyImpl.java deleted file mode 100644 index 00372b9c49..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicQosBodyImpl.java +++ /dev/null @@ -1,140 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicQosBodyImpl extends AMQMethodBody_0_91 implements BasicQosBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicQosBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final long _prefetchSize; // [prefetchSize] - private final int _prefetchCount; // [prefetchCount] - private final byte _bitfield0; // [global] - - // Constructor - public BasicQosBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _prefetchSize = readUnsignedInteger( buffer ); - _prefetchCount = readUnsignedShort( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicQosBodyImpl( - long prefetchSize, - int prefetchCount, - boolean global - ) - { - _prefetchSize = prefetchSize; - _prefetchCount = prefetchCount; - byte bitfield0 = (byte)0; - if( global ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getPrefetchSize() - { - return _prefetchSize; - } - public final int getPrefetchCount() - { - return _prefetchCount; - } - public final boolean getGlobal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 7; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _prefetchSize ); - writeUnsignedShort( buffer, _prefetchCount ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicQos(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicQosBodyImpl: "); - buf.append( "prefetchSize=" ); - buf.append( getPrefetchSize() ); - buf.append( ", " ); - buf.append( "prefetchCount=" ); - buf.append( getPrefetchCount() ); - buf.append( ", " ); - buf.append( "global=" ); - buf.append( getGlobal() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicQosOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicQosOkBodyImpl.java deleted file mode 100644 index a36b2e6d66..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicQosOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicQosOkBodyImpl extends AMQMethodBody_0_91 implements BasicQosOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicQosOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public BasicQosOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public BasicQosOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicQosOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicQosOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicRecoverBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicRecoverBodyImpl.java deleted file mode 100644 index e21c382a24..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicRecoverBodyImpl.java +++ /dev/null @@ -1,116 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicRecoverBodyImpl extends AMQMethodBody_0_91 implements BasicRecoverBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicRecoverBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 100; - - // Fields declared in specification - private final byte _bitfield0; // [requeue] - - // Constructor - public BasicRecoverBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _bitfield0 = readBitfield( buffer ); - } - - public BasicRecoverBodyImpl( - boolean requeue - ) - { - byte bitfield0 = (byte)0; - if( requeue ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final boolean getRequeue() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicRecover(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicRecoverBodyImpl: "); - buf.append( "requeue=" ); - buf.append( getRequeue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicRecoverSyncBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicRecoverSyncBodyImpl.java deleted file mode 100644 index c0679cf939..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicRecoverSyncBodyImpl.java +++ /dev/null @@ -1,116 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicRecoverSyncBodyImpl extends AMQMethodBody_0_91 implements BasicRecoverSyncBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicRecoverSyncBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 110; - - // Fields declared in specification - private final byte _bitfield0; // [requeue] - - // Constructor - public BasicRecoverSyncBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _bitfield0 = readBitfield( buffer ); - } - - public BasicRecoverSyncBodyImpl( - boolean requeue - ) - { - byte bitfield0 = (byte)0; - if( requeue ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final boolean getRequeue() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicRecoverSync(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicRecoverSyncBodyImpl: "); - buf.append( "requeue=" ); - buf.append( getRequeue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicRecoverSyncOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicRecoverSyncOkBodyImpl.java deleted file mode 100644 index a75d344831..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicRecoverSyncOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicRecoverSyncOkBodyImpl extends AMQMethodBody_0_91 implements BasicRecoverSyncOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicRecoverSyncOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 111; - - // Fields declared in specification - - // Constructor - public BasicRecoverSyncOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public BasicRecoverSyncOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicRecoverSyncOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicRecoverSyncOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicRejectBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicRejectBodyImpl.java deleted file mode 100644 index b5b549d4a9..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicRejectBodyImpl.java +++ /dev/null @@ -1,128 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicRejectBodyImpl extends AMQMethodBody_0_91 implements BasicRejectBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicRejectBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 90; - - // Fields declared in specification - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [requeue] - - // Constructor - public BasicRejectBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicRejectBodyImpl( - long deliveryTag, - boolean requeue - ) - { - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( requeue ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getRequeue() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 9; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicReject(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicRejectBodyImpl: "); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "requeue=" ); - buf.append( getRequeue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicReturnBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicReturnBodyImpl.java deleted file mode 100644 index 26ba2f8b95..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/BasicReturnBodyImpl.java +++ /dev/null @@ -1,150 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicReturnBodyImpl extends AMQMethodBody_0_91 implements BasicReturnBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicReturnBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 50; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - - // Constructor - public BasicReturnBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - } - - public BasicReturnBodyImpl( - int replyCode, - AMQShortString replyText, - AMQShortString exchange, - AMQShortString routingKey - ) - { - _replyCode = replyCode; - _replyText = replyText; - _exchange = exchange; - _routingKey = routingKey; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _replyText ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchBasicReturn(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicReturnBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelCloseBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelCloseBodyImpl.java deleted file mode 100644 index 77f0dc2c9a..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelCloseBodyImpl.java +++ /dev/null @@ -1,148 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelCloseBodyImpl extends AMQMethodBody_0_91 implements ChannelCloseBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelCloseBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final int _classId; // [classId] - private final int _methodId; // [methodId] - - // Constructor - public ChannelCloseBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _classId = readUnsignedShort( buffer ); - _methodId = readUnsignedShort( buffer ); - } - - public ChannelCloseBodyImpl( - int replyCode, - AMQShortString replyText, - int classId, - int methodId - ) - { - _replyCode = replyCode; - _replyText = replyText; - _classId = classId; - _methodId = methodId; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final int getClassId() - { - return _classId; - } - public final int getMethodId() - { - return _methodId; - } - - protected int getBodySize() - { - int size = 6; - size += getSizeOf( _replyText ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeUnsignedShort( buffer, _classId ); - writeUnsignedShort( buffer, _methodId ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchChannelClose(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelCloseBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "classId=" ); - buf.append( getClassId() ); - buf.append( ", " ); - buf.append( "methodId=" ); - buf.append( getMethodId() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelCloseOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelCloseOkBodyImpl.java deleted file mode 100644 index 91dd7b998a..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelCloseOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelCloseOkBodyImpl extends AMQMethodBody_0_91 implements ChannelCloseOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelCloseOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 41; - - // Fields declared in specification - - // Constructor - public ChannelCloseOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ChannelCloseOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchChannelCloseOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelCloseOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelFlowBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelFlowBodyImpl.java deleted file mode 100644 index ce22049d31..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelFlowBodyImpl.java +++ /dev/null @@ -1,116 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelFlowBodyImpl extends AMQMethodBody_0_91 implements ChannelFlowBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelFlowBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final byte _bitfield0; // [active] - - // Constructor - public ChannelFlowBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _bitfield0 = readBitfield( buffer ); - } - - public ChannelFlowBodyImpl( - boolean active - ) - { - byte bitfield0 = (byte)0; - if( active ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final boolean getActive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchChannelFlow(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelFlowBodyImpl: "); - buf.append( "active=" ); - buf.append( getActive() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelFlowOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelFlowOkBodyImpl.java deleted file mode 100644 index 427acd045c..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelFlowOkBodyImpl.java +++ /dev/null @@ -1,116 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelFlowOkBodyImpl extends AMQMethodBody_0_91 implements ChannelFlowOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelFlowOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final byte _bitfield0; // [active] - - // Constructor - public ChannelFlowOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _bitfield0 = readBitfield( buffer ); - } - - public ChannelFlowOkBodyImpl( - boolean active - ) - { - byte bitfield0 = (byte)0; - if( active ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final boolean getActive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchChannelFlowOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelFlowOkBodyImpl: "); - buf.append( "active=" ); - buf.append( getActive() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelOpenBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelOpenBodyImpl.java deleted file mode 100644 index e204006fb3..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelOpenBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelOpenBodyImpl extends AMQMethodBody_0_91 implements ChannelOpenBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelOpenBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final AMQShortString _outOfBand; // [outOfBand] - - // Constructor - public ChannelOpenBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _outOfBand = readAMQShortString( buffer ); - } - - public ChannelOpenBodyImpl( - AMQShortString outOfBand - ) - { - _outOfBand = outOfBand; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getOutOfBand() - { - return _outOfBand; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _outOfBand ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _outOfBand ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchChannelOpen(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelOpenBodyImpl: "); - buf.append( "outOfBand=" ); - buf.append( getOutOfBand() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelOpenOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelOpenOkBodyImpl.java deleted file mode 100644 index d891cb3374..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ChannelOpenOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelOpenOkBodyImpl extends AMQMethodBody_0_91 implements ChannelOpenOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelOpenOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 11; - - // Fields declared in specification - private final byte[] _channelId; // [channelId] - - // Constructor - public ChannelOpenOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _channelId = readBytes( buffer ); - } - - public ChannelOpenOkBodyImpl( - byte[] channelId - ) - { - _channelId = channelId; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getChannelId() - { - return _channelId; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _channelId ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _channelId ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchChannelOpenOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelOpenOkBodyImpl: "); - buf.append( "channelId=" ); - buf.append( getChannelId() == null ? "null" : java.util.Arrays.toString( getChannelId() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ClientMethodDispatcher_0_91.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ClientMethodDispatcher_0_91.java deleted file mode 100644 index e60a4b6d0c..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ClientMethodDispatcher_0_91.java +++ /dev/null @@ -1,67 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.*; - -public interface ClientMethodDispatcher_0_91 extends ClientMethodDispatcher -{ - - public boolean dispatchBasicCancelOk(BasicCancelOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicConsumeOk(BasicConsumeOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicDeliver(BasicDeliverBody body, int channelId) throws AMQException; - public boolean dispatchBasicGetEmpty(BasicGetEmptyBody body, int channelId) throws AMQException; - public boolean dispatchBasicGetOk(BasicGetOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicQosOk(BasicQosOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicRecoverSyncOk(BasicRecoverSyncOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicReturn(BasicReturnBody body, int channelId) throws AMQException; - public boolean dispatchChannelClose(ChannelCloseBody body, int channelId) throws AMQException; - public boolean dispatchChannelCloseOk(ChannelCloseOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelFlow(ChannelFlowBody body, int channelId) throws AMQException; - public boolean dispatchChannelFlowOk(ChannelFlowOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelOpenOk(ChannelOpenOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionClose(ConnectionCloseBody body, int channelId) throws AMQException; - public boolean dispatchConnectionCloseOk(ConnectionCloseOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionOpenOk(ConnectionOpenOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionSecure(ConnectionSecureBody body, int channelId) throws AMQException; - public boolean dispatchConnectionStart(ConnectionStartBody body, int channelId) throws AMQException; - public boolean dispatchConnectionTune(ConnectionTuneBody body, int channelId) throws AMQException; - public boolean dispatchExchangeBoundOk(ExchangeBoundOkBody body, int channelId) throws AMQException; - public boolean dispatchExchangeDeclareOk(ExchangeDeclareOkBody body, int channelId) throws AMQException; - public boolean dispatchExchangeDeleteOk(ExchangeDeleteOkBody body, int channelId) throws AMQException; - public boolean dispatchQueueBindOk(QueueBindOkBody body, int channelId) throws AMQException; - public boolean dispatchQueueDeclareOk(QueueDeclareOkBody body, int channelId) throws AMQException; - public boolean dispatchQueueDeleteOk(QueueDeleteOkBody body, int channelId) throws AMQException; - public boolean dispatchQueuePurgeOk(QueuePurgeOkBody body, int channelId) throws AMQException; - public boolean dispatchQueueUnbindOk(QueueUnbindOkBody body, int channelId) throws AMQException; - public boolean dispatchTxCommitOk(TxCommitOkBody body, int channelId) throws AMQException; - public boolean dispatchTxRollbackOk(TxRollbackOkBody body, int channelId) throws AMQException; - public boolean dispatchTxSelectOk(TxSelectOkBody body, int channelId) throws AMQException; - -}
\ No newline at end of file diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionCloseBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionCloseBodyImpl.java deleted file mode 100644 index 92c78ac484..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionCloseBodyImpl.java +++ /dev/null @@ -1,148 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionCloseBodyImpl extends AMQMethodBody_0_91 implements ConnectionCloseBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionCloseBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 50; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final int _classId; // [classId] - private final int _methodId; // [methodId] - - // Constructor - public ConnectionCloseBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _classId = readUnsignedShort( buffer ); - _methodId = readUnsignedShort( buffer ); - } - - public ConnectionCloseBodyImpl( - int replyCode, - AMQShortString replyText, - int classId, - int methodId - ) - { - _replyCode = replyCode; - _replyText = replyText; - _classId = classId; - _methodId = methodId; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final int getClassId() - { - return _classId; - } - public final int getMethodId() - { - return _methodId; - } - - protected int getBodySize() - { - int size = 6; - size += getSizeOf( _replyText ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeUnsignedShort( buffer, _classId ); - writeUnsignedShort( buffer, _methodId ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchConnectionClose(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionCloseBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "classId=" ); - buf.append( getClassId() ); - buf.append( ", " ); - buf.append( "methodId=" ); - buf.append( getMethodId() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionCloseOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionCloseOkBodyImpl.java deleted file mode 100644 index 8bf23cb8fb..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionCloseOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionCloseOkBodyImpl extends AMQMethodBody_0_91 implements ConnectionCloseOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionCloseOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 51; - - // Fields declared in specification - - // Constructor - public ConnectionCloseOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ConnectionCloseOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchConnectionCloseOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionCloseOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionOpenBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionOpenBodyImpl.java deleted file mode 100644 index 20284f6462..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionOpenBodyImpl.java +++ /dev/null @@ -1,142 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionOpenBodyImpl extends AMQMethodBody_0_91 implements ConnectionOpenBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionOpenBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final AMQShortString _virtualHost; // [virtualHost] - private final AMQShortString _capabilities; // [capabilities] - private final byte _bitfield0; // [insist] - - // Constructor - public ConnectionOpenBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _virtualHost = readAMQShortString( buffer ); - _capabilities = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public ConnectionOpenBodyImpl( - AMQShortString virtualHost, - AMQShortString capabilities, - boolean insist - ) - { - _virtualHost = virtualHost; - _capabilities = capabilities; - byte bitfield0 = (byte)0; - if( insist ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getVirtualHost() - { - return _virtualHost; - } - public final AMQShortString getCapabilities() - { - return _capabilities; - } - public final boolean getInsist() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - size += getSizeOf( _virtualHost ); - size += getSizeOf( _capabilities ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _virtualHost ); - writeAMQShortString( buffer, _capabilities ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchConnectionOpen(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionOpenBodyImpl: "); - buf.append( "virtualHost=" ); - buf.append( getVirtualHost() ); - buf.append( ", " ); - buf.append( "capabilities=" ); - buf.append( getCapabilities() ); - buf.append( ", " ); - buf.append( "insist=" ); - buf.append( getInsist() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionOpenOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionOpenOkBodyImpl.java deleted file mode 100644 index 346b26f039..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionOpenOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionOpenOkBodyImpl extends AMQMethodBody_0_91 implements ConnectionOpenOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionOpenOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 41; - - // Fields declared in specification - private final AMQShortString _knownHosts; // [knownHosts] - - // Constructor - public ConnectionOpenOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _knownHosts = readAMQShortString( buffer ); - } - - public ConnectionOpenOkBodyImpl( - AMQShortString knownHosts - ) - { - _knownHosts = knownHosts; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getKnownHosts() - { - return _knownHosts; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _knownHosts ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _knownHosts ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchConnectionOpenOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionOpenOkBodyImpl: "); - buf.append( "knownHosts=" ); - buf.append( getKnownHosts() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionSecureBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionSecureBodyImpl.java deleted file mode 100644 index 1573403c41..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionSecureBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionSecureBodyImpl extends AMQMethodBody_0_91 implements ConnectionSecureBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionSecureBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final byte[] _challenge; // [challenge] - - // Constructor - public ConnectionSecureBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _challenge = readBytes( buffer ); - } - - public ConnectionSecureBodyImpl( - byte[] challenge - ) - { - _challenge = challenge; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getChallenge() - { - return _challenge; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _challenge ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _challenge ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchConnectionSecure(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionSecureBodyImpl: "); - buf.append( "challenge=" ); - buf.append( getChallenge() == null ? "null" : java.util.Arrays.toString( getChallenge() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionSecureOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionSecureOkBodyImpl.java deleted file mode 100644 index bf44d51a00..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionSecureOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionSecureOkBodyImpl extends AMQMethodBody_0_91 implements ConnectionSecureOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionSecureOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final byte[] _response; // [response] - - // Constructor - public ConnectionSecureOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _response = readBytes( buffer ); - } - - public ConnectionSecureOkBodyImpl( - byte[] response - ) - { - _response = response; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getResponse() - { - return _response; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _response ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _response ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchConnectionSecureOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionSecureOkBodyImpl: "); - buf.append( "response=" ); - buf.append( getResponse() == null ? "null" : java.util.Arrays.toString( getResponse() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionStartBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionStartBodyImpl.java deleted file mode 100644 index b849c4fcfb..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionStartBodyImpl.java +++ /dev/null @@ -1,162 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionStartBodyImpl extends AMQMethodBody_0_91 implements ConnectionStartBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionStartBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final short _versionMajor; // [versionMajor] - private final short _versionMinor; // [versionMinor] - private final FieldTable _serverProperties; // [serverProperties] - private final byte[] _mechanisms; // [mechanisms] - private final byte[] _locales; // [locales] - - // Constructor - public ConnectionStartBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _versionMajor = readUnsignedByte( buffer ); - _versionMinor = readUnsignedByte( buffer ); - _serverProperties = readFieldTable( buffer ); - _mechanisms = readBytes( buffer ); - _locales = readBytes( buffer ); - } - - public ConnectionStartBodyImpl( - short versionMajor, - short versionMinor, - FieldTable serverProperties, - byte[] mechanisms, - byte[] locales - ) - { - _versionMajor = versionMajor; - _versionMinor = versionMinor; - _serverProperties = serverProperties; - _mechanisms = mechanisms; - _locales = locales; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final short getVersionMajor() - { - return _versionMajor; - } - public final short getVersionMinor() - { - return _versionMinor; - } - public final FieldTable getServerProperties() - { - return _serverProperties; - } - public final byte[] getMechanisms() - { - return _mechanisms; - } - public final byte[] getLocales() - { - return _locales; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _serverProperties ); - size += getSizeOf( _mechanisms ); - size += getSizeOf( _locales ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedByte( buffer, _versionMajor ); - writeUnsignedByte( buffer, _versionMinor ); - writeFieldTable( buffer, _serverProperties ); - writeBytes( buffer, _mechanisms ); - writeBytes( buffer, _locales ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchConnectionStart(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionStartBodyImpl: "); - buf.append( "versionMajor=" ); - buf.append( getVersionMajor() ); - buf.append( ", " ); - buf.append( "versionMinor=" ); - buf.append( getVersionMinor() ); - buf.append( ", " ); - buf.append( "serverProperties=" ); - buf.append( getServerProperties() ); - buf.append( ", " ); - buf.append( "mechanisms=" ); - buf.append( getMechanisms() == null ? "null" : java.util.Arrays.toString( getMechanisms() ) ); - buf.append( ", " ); - buf.append( "locales=" ); - buf.append( getLocales() == null ? "null" : java.util.Arrays.toString( getLocales() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionStartOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionStartOkBodyImpl.java deleted file mode 100644 index 59bbf147e3..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionStartOkBodyImpl.java +++ /dev/null @@ -1,151 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionStartOkBodyImpl extends AMQMethodBody_0_91 implements ConnectionStartOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionStartOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 11; - - // Fields declared in specification - private final FieldTable _clientProperties; // [clientProperties] - private final AMQShortString _mechanism; // [mechanism] - private final byte[] _response; // [response] - private final AMQShortString _locale; // [locale] - - // Constructor - public ConnectionStartOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _clientProperties = readFieldTable( buffer ); - _mechanism = readAMQShortString( buffer ); - _response = readBytes( buffer ); - _locale = readAMQShortString( buffer ); - } - - public ConnectionStartOkBodyImpl( - FieldTable clientProperties, - AMQShortString mechanism, - byte[] response, - AMQShortString locale - ) - { - _clientProperties = clientProperties; - _mechanism = mechanism; - _response = response; - _locale = locale; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final FieldTable getClientProperties() - { - return _clientProperties; - } - public final AMQShortString getMechanism() - { - return _mechanism; - } - public final byte[] getResponse() - { - return _response; - } - public final AMQShortString getLocale() - { - return _locale; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _clientProperties ); - size += getSizeOf( _mechanism ); - size += getSizeOf( _response ); - size += getSizeOf( _locale ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeFieldTable( buffer, _clientProperties ); - writeAMQShortString( buffer, _mechanism ); - writeBytes( buffer, _response ); - writeAMQShortString( buffer, _locale ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchConnectionStartOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionStartOkBodyImpl: "); - buf.append( "clientProperties=" ); - buf.append( getClientProperties() ); - buf.append( ", " ); - buf.append( "mechanism=" ); - buf.append( getMechanism() ); - buf.append( ", " ); - buf.append( "response=" ); - buf.append( getResponse() == null ? "null" : java.util.Arrays.toString( getResponse() ) ); - buf.append( ", " ); - buf.append( "locale=" ); - buf.append( getLocale() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionTuneBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionTuneBodyImpl.java deleted file mode 100644 index 2c98b56858..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionTuneBodyImpl.java +++ /dev/null @@ -1,135 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionTuneBodyImpl extends AMQMethodBody_0_91 implements ConnectionTuneBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionTuneBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final int _channelMax; // [channelMax] - private final long _frameMax; // [frameMax] - private final int _heartbeat; // [heartbeat] - - // Constructor - public ConnectionTuneBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _channelMax = readUnsignedShort( buffer ); - _frameMax = readUnsignedInteger( buffer ); - _heartbeat = readUnsignedShort( buffer ); - } - - public ConnectionTuneBodyImpl( - int channelMax, - long frameMax, - int heartbeat - ) - { - _channelMax = channelMax; - _frameMax = frameMax; - _heartbeat = heartbeat; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getChannelMax() - { - return _channelMax; - } - public final long getFrameMax() - { - return _frameMax; - } - public final int getHeartbeat() - { - return _heartbeat; - } - - protected int getBodySize() - { - int size = 8; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _channelMax ); - writeUnsignedInteger( buffer, _frameMax ); - writeUnsignedShort( buffer, _heartbeat ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchConnectionTune(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionTuneBodyImpl: "); - buf.append( "channelMax=" ); - buf.append( getChannelMax() ); - buf.append( ", " ); - buf.append( "frameMax=" ); - buf.append( getFrameMax() ); - buf.append( ", " ); - buf.append( "heartbeat=" ); - buf.append( getHeartbeat() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionTuneOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionTuneOkBodyImpl.java deleted file mode 100644 index 8a6a6aac3a..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ConnectionTuneOkBodyImpl.java +++ /dev/null @@ -1,135 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionTuneOkBodyImpl extends AMQMethodBody_0_91 implements ConnectionTuneOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionTuneOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final int _channelMax; // [channelMax] - private final long _frameMax; // [frameMax] - private final int _heartbeat; // [heartbeat] - - // Constructor - public ConnectionTuneOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _channelMax = readUnsignedShort( buffer ); - _frameMax = readUnsignedInteger( buffer ); - _heartbeat = readUnsignedShort( buffer ); - } - - public ConnectionTuneOkBodyImpl( - int channelMax, - long frameMax, - int heartbeat - ) - { - _channelMax = channelMax; - _frameMax = frameMax; - _heartbeat = heartbeat; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getChannelMax() - { - return _channelMax; - } - public final long getFrameMax() - { - return _frameMax; - } - public final int getHeartbeat() - { - return _heartbeat; - } - - protected int getBodySize() - { - int size = 8; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _channelMax ); - writeUnsignedInteger( buffer, _frameMax ); - writeUnsignedShort( buffer, _heartbeat ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchConnectionTuneOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionTuneOkBodyImpl: "); - buf.append( "channelMax=" ); - buf.append( getChannelMax() ); - buf.append( ", " ); - buf.append( "frameMax=" ); - buf.append( getFrameMax() ); - buf.append( ", " ); - buf.append( "heartbeat=" ); - buf.append( getHeartbeat() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeBoundBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeBoundBodyImpl.java deleted file mode 100644 index 69e70d7477..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeBoundBodyImpl.java +++ /dev/null @@ -1,138 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeBoundBodyImpl extends AMQMethodBody_0_91 implements ExchangeBoundBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeBoundBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 22; - - // Fields declared in specification - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final AMQShortString _queue; // [queue] - - // Constructor - public ExchangeBoundBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _queue = readAMQShortString( buffer ); - } - - public ExchangeBoundBodyImpl( - AMQShortString exchange, - AMQShortString routingKey, - AMQShortString queue - ) - { - _exchange = exchange; - _routingKey = routingKey; - _queue = queue; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final AMQShortString getQueue() - { - return _queue; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeAMQShortString( buffer, _queue ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchExchangeBound(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeBoundBodyImpl: "); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeBoundOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeBoundOkBodyImpl.java deleted file mode 100644 index c21838081f..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeBoundOkBodyImpl.java +++ /dev/null @@ -1,124 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeBoundOkBodyImpl extends AMQMethodBody_0_91 implements ExchangeBoundOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeBoundOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 23; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - - // Constructor - public ExchangeBoundOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - } - - public ExchangeBoundOkBodyImpl( - int replyCode, - AMQShortString replyText - ) - { - _replyCode = replyCode; - _replyText = replyText; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _replyText ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchExchangeBoundOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeBoundOkBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeDeclareBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeDeclareBodyImpl.java deleted file mode 100644 index 68b9ce084d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeDeclareBodyImpl.java +++ /dev/null @@ -1,220 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeDeclareBodyImpl extends AMQMethodBody_0_91 implements ExchangeDeclareBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeDeclareBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _type; // [type] - private final byte _bitfield0; // [passive, durable, autoDelete, internal, nowait] - private final FieldTable _arguments; // [arguments] - - // Constructor - public ExchangeDeclareBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _exchange = readAMQShortString( buffer ); - _type = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _arguments = readFieldTable( buffer ); - } - - public ExchangeDeclareBodyImpl( - int ticket, - AMQShortString exchange, - AMQShortString type, - boolean passive, - boolean durable, - boolean autoDelete, - boolean internal, - boolean nowait, - FieldTable arguments - ) - { - _ticket = ticket; - _exchange = exchange; - _type = type; - byte bitfield0 = (byte)0; - if( passive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( durable ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( autoDelete ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - if( internal ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 4)); - } - - _bitfield0 = bitfield0; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getType() - { - return _type; - } - public final boolean getPassive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getDurable() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getAutoDelete() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final boolean getInternal() - { - return (((int)(_bitfield0)) & ( 1 << 3)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 4)) != 0; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _exchange ); - size += getSizeOf( _type ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _type ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchExchangeDeclare(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeDeclareBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "type=" ); - buf.append( getType() ); - buf.append( ", " ); - buf.append( "passive=" ); - buf.append( getPassive() ); - buf.append( ", " ); - buf.append( "durable=" ); - buf.append( getDurable() ); - buf.append( ", " ); - buf.append( "autoDelete=" ); - buf.append( getAutoDelete() ); - buf.append( ", " ); - buf.append( "internal=" ); - buf.append( getInternal() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeDeclareOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeDeclareOkBodyImpl.java deleted file mode 100644 index 2861d1e954..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeDeclareOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeDeclareOkBodyImpl extends AMQMethodBody_0_91 implements ExchangeDeclareOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeDeclareOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public ExchangeDeclareOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ExchangeDeclareOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchExchangeDeclareOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeDeclareOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeDeleteBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeDeleteBodyImpl.java deleted file mode 100644 index f259d6433d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeDeleteBodyImpl.java +++ /dev/null @@ -1,154 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeDeleteBodyImpl extends AMQMethodBody_0_91 implements ExchangeDeleteBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeDeleteBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _exchange; // [exchange] - private final byte _bitfield0; // [ifUnused, nowait] - - // Constructor - public ExchangeDeleteBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _exchange = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public ExchangeDeleteBodyImpl( - int ticket, - AMQShortString exchange, - boolean ifUnused, - boolean nowait - ) - { - _ticket = ticket; - _exchange = exchange; - byte bitfield0 = (byte)0; - if( ifUnused ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final boolean getIfUnused() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _exchange ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _exchange ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchExchangeDelete(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeDeleteBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "ifUnused=" ); - buf.append( getIfUnused() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeDeleteOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeDeleteOkBodyImpl.java deleted file mode 100644 index fc4ef99a5b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ExchangeDeleteOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeDeleteOkBodyImpl extends AMQMethodBody_0_91 implements ExchangeDeleteOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeDeleteOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 21; - - // Fields declared in specification - - // Constructor - public ExchangeDeleteOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ExchangeDeleteOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchExchangeDeleteOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeDeleteOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/MethodConverter_0_91.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/MethodConverter_0_91.java deleted file mode 100644 index e25dc8a022..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/MethodConverter_0_91.java +++ /dev/null @@ -1,66 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.BasicPublishBody; -import org.apache.qpid.framing.abstraction.AbstractMethodConverter; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; -import org.apache.qpid.framing.abstraction.MessagePublishInfoImpl; -import org.apache.qpid.framing.abstraction.ProtocolVersionMethodConverter; - -public class MethodConverter_0_91 extends AbstractMethodConverter implements ProtocolVersionMethodConverter -{ - - public MethodConverter_0_91() - { - super((byte)0,(byte)9); - } - - - public MessagePublishInfo convertToInfo(AMQMethodBody methodBody) - { - final BasicPublishBody publishBody = ((BasicPublishBody) methodBody); - - final AMQShortString exchange = publishBody.getExchange(); - final AMQShortString routingKey = publishBody.getRoutingKey(); - - return new MessagePublishInfoImpl(exchange, - publishBody.getImmediate(), - publishBody.getMandatory(), - routingKey); - - } - - public AMQMethodBody convertToBody(MessagePublishInfo info) - { - - return new BasicPublishBodyImpl(0, - info.getExchange(), - info.getRoutingKey(), - info.isMandatory(), - info.isImmediate()) ; - - } - -}
\ No newline at end of file diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/MethodDispatcher_0_91.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/MethodDispatcher_0_91.java deleted file mode 100644 index 9846ce4b48..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/MethodDispatcher_0_91.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.framing.*; - -public interface MethodDispatcher_0_91 - extends MethodDispatcher, - ServerMethodDispatcher_0_91, - ClientMethodDispatcher_0_91 -{ - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/MethodRegistry_0_91.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/MethodRegistry_0_91.java deleted file mode 100644 index 40970f2266..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/MethodRegistry_0_91.java +++ /dev/null @@ -1,877 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.framing.*; -import org.apache.qpid.protocol.AMQConstant; - - -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import java.io.IOException; - -import org.apache.qpid.framing.abstraction.ProtocolVersionMethodConverter; -import org.apache.qpid.codec.MarkableDataInput; - - -public class MethodRegistry_0_91 extends MethodRegistry -{ - - private static final Logger _log = LoggerFactory.getLogger(MethodRegistry.class); - - private ProtocolVersionMethodConverter _protocolVersionConverter = new MethodConverter_0_91(); - - private final AMQMethodBodyInstanceFactory[][] _factories = new AMQMethodBodyInstanceFactory[91][]; - - public MethodRegistry_0_91() - { - this(new ProtocolVersion((byte)0,(byte)91)); - } - - public MethodRegistry_0_91(ProtocolVersion pv) - { - super(pv); - - - - // Register method body instance factories for the Connection class. - - _factories[10] = new AMQMethodBodyInstanceFactory[52]; - - _factories[10][10] = ConnectionStartBodyImpl.getFactory(); - _factories[10][11] = ConnectionStartOkBodyImpl.getFactory(); - _factories[10][20] = ConnectionSecureBodyImpl.getFactory(); - _factories[10][21] = ConnectionSecureOkBodyImpl.getFactory(); - _factories[10][30] = ConnectionTuneBodyImpl.getFactory(); - _factories[10][31] = ConnectionTuneOkBodyImpl.getFactory(); - _factories[10][40] = ConnectionOpenBodyImpl.getFactory(); - _factories[10][41] = ConnectionOpenOkBodyImpl.getFactory(); - _factories[10][50] = ConnectionCloseBodyImpl.getFactory(); - _factories[10][51] = ConnectionCloseOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Channel class. - - _factories[20] = new AMQMethodBodyInstanceFactory[42]; - - _factories[20][10] = ChannelOpenBodyImpl.getFactory(); - _factories[20][11] = ChannelOpenOkBodyImpl.getFactory(); - _factories[20][20] = ChannelFlowBodyImpl.getFactory(); - _factories[20][21] = ChannelFlowOkBodyImpl.getFactory(); - _factories[20][40] = ChannelCloseBodyImpl.getFactory(); - _factories[20][41] = ChannelCloseOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Exchange class. - - _factories[40] = new AMQMethodBodyInstanceFactory[24]; - - _factories[40][10] = ExchangeDeclareBodyImpl.getFactory(); - _factories[40][11] = ExchangeDeclareOkBodyImpl.getFactory(); - _factories[40][20] = ExchangeDeleteBodyImpl.getFactory(); - _factories[40][21] = ExchangeDeleteOkBodyImpl.getFactory(); - _factories[40][22] = ExchangeBoundBodyImpl.getFactory(); - _factories[40][23] = ExchangeBoundOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Queue class. - - _factories[50] = new AMQMethodBodyInstanceFactory[52]; - - _factories[50][10] = QueueDeclareBodyImpl.getFactory(); - _factories[50][11] = QueueDeclareOkBodyImpl.getFactory(); - _factories[50][20] = QueueBindBodyImpl.getFactory(); - _factories[50][21] = QueueBindOkBodyImpl.getFactory(); - _factories[50][30] = QueuePurgeBodyImpl.getFactory(); - _factories[50][31] = QueuePurgeOkBodyImpl.getFactory(); - _factories[50][40] = QueueDeleteBodyImpl.getFactory(); - _factories[50][41] = QueueDeleteOkBodyImpl.getFactory(); - _factories[50][50] = QueueUnbindBodyImpl.getFactory(); - _factories[50][51] = QueueUnbindOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Basic class. - - _factories[60] = new AMQMethodBodyInstanceFactory[112]; - - _factories[60][10] = BasicQosBodyImpl.getFactory(); - _factories[60][11] = BasicQosOkBodyImpl.getFactory(); - _factories[60][20] = BasicConsumeBodyImpl.getFactory(); - _factories[60][21] = BasicConsumeOkBodyImpl.getFactory(); - _factories[60][30] = BasicCancelBodyImpl.getFactory(); - _factories[60][31] = BasicCancelOkBodyImpl.getFactory(); - _factories[60][40] = BasicPublishBodyImpl.getFactory(); - _factories[60][50] = BasicReturnBodyImpl.getFactory(); - _factories[60][60] = BasicDeliverBodyImpl.getFactory(); - _factories[60][70] = BasicGetBodyImpl.getFactory(); - _factories[60][71] = BasicGetOkBodyImpl.getFactory(); - _factories[60][72] = BasicGetEmptyBodyImpl.getFactory(); - _factories[60][80] = BasicAckBodyImpl.getFactory(); - _factories[60][90] = BasicRejectBodyImpl.getFactory(); - _factories[60][100] = BasicRecoverBodyImpl.getFactory(); - _factories[60][110] = BasicRecoverSyncBodyImpl.getFactory(); - _factories[60][111] = BasicRecoverSyncOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Tx class. - - _factories[90] = new AMQMethodBodyInstanceFactory[32]; - - _factories[90][10] = TxSelectBodyImpl.getFactory(); - _factories[90][11] = TxSelectOkBodyImpl.getFactory(); - _factories[90][20] = TxCommitBodyImpl.getFactory(); - _factories[90][21] = TxCommitOkBodyImpl.getFactory(); - _factories[90][30] = TxRollbackBodyImpl.getFactory(); - _factories[90][31] = TxRollbackOkBodyImpl.getFactory(); - } - - public AMQMethodBody convertToBody(MarkableDataInput in, long size) - throws AMQFrameDecodingException, IOException - { - int classId = in.readUnsignedShort(); - int methodId = in.readUnsignedShort(); - - AMQMethodBodyInstanceFactory bodyFactory; - try - { - bodyFactory = _factories[classId][methodId]; - } - catch(NullPointerException e) - { - throw new AMQFrameDecodingException(AMQConstant.COMMAND_INVALID, - "Class " + classId + " unknown in AMQP version 0-91" - + " (while trying to decode class " + classId + " method " + methodId + "."); - } - catch(IndexOutOfBoundsException e) - { - if(classId >= _factories.length) - { - throw new AMQFrameDecodingException(AMQConstant.COMMAND_INVALID, - "Class " + classId + " unknown in AMQP version 0-91" - + " (while trying to decode class " + classId + " method " + methodId + "."); - - } - else - { - throw new AMQFrameDecodingException(AMQConstant.COMMAND_INVALID, - "Method " + methodId + " unknown in AMQP version 0-91" - + " (while trying to decode class " + classId + " method " + methodId + "."); - - } - } - - if (bodyFactory == null) - { - throw new AMQFrameDecodingException(AMQConstant.COMMAND_INVALID, - "Method " + methodId + " unknown in AMQP version 0-91" - + " (while trying to decode class " + classId + " method " + methodId + "."); - } - - return bodyFactory.newInstance(in, size); - } - - public int getMaxClassId() - { - return 90; - } - - public int getMaxMethodId(int classId) - { - return _factories[classId].length - 1; - } - - - - public ConnectionStartBody createConnectionStartBody( - final short versionMajor, - final short versionMinor, - final FieldTable serverProperties, - final byte[] mechanisms, - final byte[] locales - ) - { - return new ConnectionStartBodyImpl( - versionMajor, - versionMinor, - serverProperties, - mechanisms, - locales - ); - } - - public ConnectionStartOkBody createConnectionStartOkBody( - final FieldTable clientProperties, - final AMQShortString mechanism, - final byte[] response, - final AMQShortString locale - ) - { - return new ConnectionStartOkBodyImpl( - clientProperties, - mechanism, - response, - locale - ); - } - - public ConnectionSecureBody createConnectionSecureBody( - final byte[] challenge - ) - { - return new ConnectionSecureBodyImpl( - challenge - ); - } - - public ConnectionSecureOkBody createConnectionSecureOkBody( - final byte[] response - ) - { - return new ConnectionSecureOkBodyImpl( - response - ); - } - - public ConnectionTuneBody createConnectionTuneBody( - final int channelMax, - final long frameMax, - final int heartbeat - ) - { - return new ConnectionTuneBodyImpl( - channelMax, - frameMax, - heartbeat - ); - } - - public ConnectionTuneOkBody createConnectionTuneOkBody( - final int channelMax, - final long frameMax, - final int heartbeat - ) - { - return new ConnectionTuneOkBodyImpl( - channelMax, - frameMax, - heartbeat - ); - } - - public ConnectionOpenBody createConnectionOpenBody( - final AMQShortString virtualHost, - final AMQShortString capabilities, - final boolean insist - ) - { - return new ConnectionOpenBodyImpl( - virtualHost, - capabilities, - insist - ); - } - - public ConnectionOpenOkBody createConnectionOpenOkBody( - final AMQShortString knownHosts - ) - { - return new ConnectionOpenOkBodyImpl( - knownHosts - ); - } - - public ConnectionCloseBody createConnectionCloseBody( - final int replyCode, - final AMQShortString replyText, - final int classId, - final int methodId - ) - { - return new ConnectionCloseBodyImpl( - replyCode, - replyText, - classId, - methodId - ); - } - - public ConnectionCloseOkBody createConnectionCloseOkBody( - ) - { - return new ConnectionCloseOkBodyImpl( - ); - } - - - - - public ChannelOpenBody createChannelOpenBody( - final AMQShortString outOfBand - ) - { - return new ChannelOpenBodyImpl( - outOfBand - ); - } - - public ChannelOpenOkBody createChannelOpenOkBody( - final byte[] channelId - ) - { - return new ChannelOpenOkBodyImpl( - channelId - ); - } - - public ChannelFlowBody createChannelFlowBody( - final boolean active - ) - { - return new ChannelFlowBodyImpl( - active - ); - } - - public ChannelFlowOkBody createChannelFlowOkBody( - final boolean active - ) - { - return new ChannelFlowOkBodyImpl( - active - ); - } - - public ChannelCloseBody createChannelCloseBody( - final int replyCode, - final AMQShortString replyText, - final int classId, - final int methodId - ) - { - return new ChannelCloseBodyImpl( - replyCode, - replyText, - classId, - methodId - ); - } - - public ChannelCloseOkBody createChannelCloseOkBody( - ) - { - return new ChannelCloseOkBodyImpl( - ); - } - - - - - public ExchangeDeclareBody createExchangeDeclareBody( - final int ticket, - final AMQShortString exchange, - final AMQShortString type, - final boolean passive, - final boolean durable, - final boolean autoDelete, - final boolean internal, - final boolean nowait, - final FieldTable arguments - ) - { - return new ExchangeDeclareBodyImpl( - ticket, - exchange, - type, - passive, - durable, - autoDelete, - internal, - nowait, - arguments - ); - } - - public ExchangeDeclareOkBody createExchangeDeclareOkBody( - ) - { - return new ExchangeDeclareOkBodyImpl( - ); - } - - public ExchangeDeleteBody createExchangeDeleteBody( - final int ticket, - final AMQShortString exchange, - final boolean ifUnused, - final boolean nowait - ) - { - return new ExchangeDeleteBodyImpl( - ticket, - exchange, - ifUnused, - nowait - ); - } - - public ExchangeDeleteOkBody createExchangeDeleteOkBody( - ) - { - return new ExchangeDeleteOkBodyImpl( - ); - } - - public ExchangeBoundBody createExchangeBoundBody( - final AMQShortString exchange, - final AMQShortString routingKey, - final AMQShortString queue - ) - { - return new ExchangeBoundBodyImpl( - exchange, - routingKey, - queue - ); - } - - public ExchangeBoundOkBody createExchangeBoundOkBody( - final int replyCode, - final AMQShortString replyText - ) - { - return new ExchangeBoundOkBodyImpl( - replyCode, - replyText - ); - } - - - - - public QueueDeclareBody createQueueDeclareBody( - final int ticket, - final AMQShortString queue, - final boolean passive, - final boolean durable, - final boolean exclusive, - final boolean autoDelete, - final boolean nowait, - final FieldTable arguments - ) - { - return new QueueDeclareBodyImpl( - ticket, - queue, - passive, - durable, - exclusive, - autoDelete, - nowait, - arguments - ); - } - - public QueueDeclareOkBody createQueueDeclareOkBody( - final AMQShortString queue, - final long messageCount, - final long consumerCount - ) - { - return new QueueDeclareOkBodyImpl( - queue, - messageCount, - consumerCount - ); - } - - public QueueBindBody createQueueBindBody( - final int ticket, - final AMQShortString queue, - final AMQShortString exchange, - final AMQShortString routingKey, - final boolean nowait, - final FieldTable arguments - ) - { - return new QueueBindBodyImpl( - ticket, - queue, - exchange, - routingKey, - nowait, - arguments - ); - } - - public QueueBindOkBody createQueueBindOkBody( - ) - { - return new QueueBindOkBodyImpl( - ); - } - - public QueuePurgeBody createQueuePurgeBody( - final int ticket, - final AMQShortString queue, - final boolean nowait - ) - { - return new QueuePurgeBodyImpl( - ticket, - queue, - nowait - ); - } - - public QueuePurgeOkBody createQueuePurgeOkBody( - final long messageCount - ) - { - return new QueuePurgeOkBodyImpl( - messageCount - ); - } - - public QueueDeleteBody createQueueDeleteBody( - final int ticket, - final AMQShortString queue, - final boolean ifUnused, - final boolean ifEmpty, - final boolean nowait - ) - { - return new QueueDeleteBodyImpl( - ticket, - queue, - ifUnused, - ifEmpty, - nowait - ); - } - - public QueueDeleteOkBody createQueueDeleteOkBody( - final long messageCount - ) - { - return new QueueDeleteOkBodyImpl( - messageCount - ); - } - - public QueueUnbindBody createQueueUnbindBody( - final int ticket, - final AMQShortString queue, - final AMQShortString exchange, - final AMQShortString routingKey, - final FieldTable arguments - ) - { - return new QueueUnbindBodyImpl( - ticket, - queue, - exchange, - routingKey, - arguments - ); - } - - public QueueUnbindOkBody createQueueUnbindOkBody( - ) - { - return new QueueUnbindOkBodyImpl( - ); - } - - - - - public BasicQosBody createBasicQosBody( - final long prefetchSize, - final int prefetchCount, - final boolean global - ) - { - return new BasicQosBodyImpl( - prefetchSize, - prefetchCount, - global - ); - } - - public BasicQosOkBody createBasicQosOkBody( - ) - { - return new BasicQosOkBodyImpl( - ); - } - - public BasicConsumeBody createBasicConsumeBody( - final int ticket, - final AMQShortString queue, - final AMQShortString consumerTag, - final boolean noLocal, - final boolean noAck, - final boolean exclusive, - final boolean nowait, - final FieldTable arguments - ) - { - return new BasicConsumeBodyImpl( - ticket, - queue, - consumerTag, - noLocal, - noAck, - exclusive, - nowait, - arguments - ); - } - - public BasicConsumeOkBody createBasicConsumeOkBody( - final AMQShortString consumerTag - ) - { - return new BasicConsumeOkBodyImpl( - consumerTag - ); - } - - public BasicCancelBody createBasicCancelBody( - final AMQShortString consumerTag, - final boolean nowait - ) - { - return new BasicCancelBodyImpl( - consumerTag, - nowait - ); - } - - public BasicCancelOkBody createBasicCancelOkBody( - final AMQShortString consumerTag - ) - { - return new BasicCancelOkBodyImpl( - consumerTag - ); - } - - public BasicPublishBody createBasicPublishBody( - final int ticket, - final AMQShortString exchange, - final AMQShortString routingKey, - final boolean mandatory, - final boolean immediate - ) - { - return new BasicPublishBodyImpl( - ticket, - exchange, - routingKey, - mandatory, - immediate - ); - } - - public BasicReturnBody createBasicReturnBody( - final int replyCode, - final AMQShortString replyText, - final AMQShortString exchange, - final AMQShortString routingKey - ) - { - return new BasicReturnBodyImpl( - replyCode, - replyText, - exchange, - routingKey - ); - } - - public BasicDeliverBody createBasicDeliverBody( - final AMQShortString consumerTag, - final long deliveryTag, - final boolean redelivered, - final AMQShortString exchange, - final AMQShortString routingKey - ) - { - return new BasicDeliverBodyImpl( - consumerTag, - deliveryTag, - redelivered, - exchange, - routingKey - ); - } - - public BasicGetBody createBasicGetBody( - final int ticket, - final AMQShortString queue, - final boolean noAck - ) - { - return new BasicGetBodyImpl( - ticket, - queue, - noAck - ); - } - - public BasicGetOkBody createBasicGetOkBody( - final long deliveryTag, - final boolean redelivered, - final AMQShortString exchange, - final AMQShortString routingKey, - final long messageCount - ) - { - return new BasicGetOkBodyImpl( - deliveryTag, - redelivered, - exchange, - routingKey, - messageCount - ); - } - - public BasicGetEmptyBody createBasicGetEmptyBody( - final AMQShortString clusterId - ) - { - return new BasicGetEmptyBodyImpl( - clusterId - ); - } - - public BasicAckBody createBasicAckBody( - final long deliveryTag, - final boolean multiple - ) - { - return new BasicAckBodyImpl( - deliveryTag, - multiple - ); - } - - public BasicRejectBody createBasicRejectBody( - final long deliveryTag, - final boolean requeue - ) - { - return new BasicRejectBodyImpl( - deliveryTag, - requeue - ); - } - - public BasicRecoverBody createBasicRecoverBody( - final boolean requeue - ) - { - return new BasicRecoverBodyImpl( - requeue - ); - } - - public BasicRecoverSyncBody createBasicRecoverSyncBody( - final boolean requeue - ) - { - return new BasicRecoverSyncBodyImpl( - requeue - ); - } - - public BasicRecoverSyncOkBody createBasicRecoverSyncOkBody( - ) - { - return new BasicRecoverSyncOkBodyImpl( - ); - } - - - - - public TxSelectBody createTxSelectBody( - ) - { - return new TxSelectBodyImpl( - ); - } - - public TxSelectOkBody createTxSelectOkBody( - ) - { - return new TxSelectOkBodyImpl( - ); - } - - public TxCommitBody createTxCommitBody( - ) - { - return new TxCommitBodyImpl( - ); - } - - public TxCommitOkBody createTxCommitOkBody( - ) - { - return new TxCommitOkBodyImpl( - ); - } - - public TxRollbackBody createTxRollbackBody( - ) - { - return new TxRollbackBodyImpl( - ); - } - - public TxRollbackOkBody createTxRollbackOkBody( - ) - { - return new TxRollbackOkBodyImpl( - ); - } - - - - public ProtocolVersionMethodConverter getProtocolVersionMethodConverter() - { - return _protocolVersionConverter; - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueBindBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueBindBodyImpl.java deleted file mode 100644 index 3c79181d1d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueBindBodyImpl.java +++ /dev/null @@ -1,181 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueBindBodyImpl extends AMQMethodBody_0_91 implements QueueBindBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueBindBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final byte _bitfield0; // [nowait] - private final FieldTable _arguments; // [arguments] - - // Constructor - public QueueBindBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _arguments = readFieldTable( buffer ); - } - - public QueueBindBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString exchange, - AMQShortString routingKey, - boolean nowait, - FieldTable arguments - ) - { - _ticket = ticket; - _queue = queue; - _exchange = exchange; - _routingKey = routingKey; - byte bitfield0 = (byte)0; - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - _bitfield0 = bitfield0; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchQueueBind(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueBindBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueBindOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueBindOkBodyImpl.java deleted file mode 100644 index b73ed8840d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueBindOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueBindOkBodyImpl extends AMQMethodBody_0_91 implements QueueBindOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueBindOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 21; - - // Fields declared in specification - - // Constructor - public QueueBindOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public QueueBindOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchQueueBindOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueBindOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueDeclareBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueDeclareBodyImpl.java deleted file mode 100644 index 3f315cd239..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueDeclareBodyImpl.java +++ /dev/null @@ -1,207 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueDeclareBodyImpl extends AMQMethodBody_0_91 implements QueueDeclareBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueDeclareBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final byte _bitfield0; // [passive, durable, exclusive, autoDelete, nowait] - private final FieldTable _arguments; // [arguments] - - // Constructor - public QueueDeclareBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _arguments = readFieldTable( buffer ); - } - - public QueueDeclareBodyImpl( - int ticket, - AMQShortString queue, - boolean passive, - boolean durable, - boolean exclusive, - boolean autoDelete, - boolean nowait, - FieldTable arguments - ) - { - _ticket = ticket; - _queue = queue; - byte bitfield0 = (byte)0; - if( passive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( durable ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( exclusive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - if( autoDelete ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 4)); - } - - _bitfield0 = bitfield0; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final boolean getPassive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getDurable() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getExclusive() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final boolean getAutoDelete() - { - return (((int)(_bitfield0)) & ( 1 << 3)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 4)) != 0; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchQueueDeclare(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueDeclareBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "passive=" ); - buf.append( getPassive() ); - buf.append( ", " ); - buf.append( "durable=" ); - buf.append( getDurable() ); - buf.append( ", " ); - buf.append( "exclusive=" ); - buf.append( getExclusive() ); - buf.append( ", " ); - buf.append( "autoDelete=" ); - buf.append( getAutoDelete() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueDeclareOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueDeclareOkBodyImpl.java deleted file mode 100644 index 6f4452199d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueDeclareOkBodyImpl.java +++ /dev/null @@ -1,136 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueDeclareOkBodyImpl extends AMQMethodBody_0_91 implements QueueDeclareOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueDeclareOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 11; - - // Fields declared in specification - private final AMQShortString _queue; // [queue] - private final long _messageCount; // [messageCount] - private final long _consumerCount; // [consumerCount] - - // Constructor - public QueueDeclareOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _queue = readAMQShortString( buffer ); - _messageCount = readUnsignedInteger( buffer ); - _consumerCount = readUnsignedInteger( buffer ); - } - - public QueueDeclareOkBodyImpl( - AMQShortString queue, - long messageCount, - long consumerCount - ) - { - _queue = queue; - _messageCount = messageCount; - _consumerCount = consumerCount; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getQueue() - { - return _queue; - } - public final long getMessageCount() - { - return _messageCount; - } - public final long getConsumerCount() - { - return _consumerCount; - } - - protected int getBodySize() - { - int size = 8; - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _queue ); - writeUnsignedInteger( buffer, _messageCount ); - writeUnsignedInteger( buffer, _consumerCount ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchQueueDeclareOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueDeclareOkBodyImpl: "); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "messageCount=" ); - buf.append( getMessageCount() ); - buf.append( ", " ); - buf.append( "consumerCount=" ); - buf.append( getConsumerCount() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueDeleteBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueDeleteBodyImpl.java deleted file mode 100644 index 1d021d9c18..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueDeleteBodyImpl.java +++ /dev/null @@ -1,167 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueDeleteBodyImpl extends AMQMethodBody_0_91 implements QueueDeleteBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueDeleteBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final byte _bitfield0; // [ifUnused, ifEmpty, nowait] - - // Constructor - public QueueDeleteBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public QueueDeleteBodyImpl( - int ticket, - AMQShortString queue, - boolean ifUnused, - boolean ifEmpty, - boolean nowait - ) - { - _ticket = ticket; - _queue = queue; - byte bitfield0 = (byte)0; - if( ifUnused ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( ifEmpty ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final boolean getIfUnused() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getIfEmpty() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchQueueDelete(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueDeleteBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "ifUnused=" ); - buf.append( getIfUnused() ); - buf.append( ", " ); - buf.append( "ifEmpty=" ); - buf.append( getIfEmpty() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueDeleteOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueDeleteOkBodyImpl.java deleted file mode 100644 index 30e54e15a2..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueDeleteOkBodyImpl.java +++ /dev/null @@ -1,111 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueDeleteOkBodyImpl extends AMQMethodBody_0_91 implements QueueDeleteOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueDeleteOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 41; - - // Fields declared in specification - private final long _messageCount; // [messageCount] - - // Constructor - public QueueDeleteOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _messageCount = readUnsignedInteger( buffer ); - } - - public QueueDeleteOkBodyImpl( - long messageCount - ) - { - _messageCount = messageCount; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getMessageCount() - { - return _messageCount; - } - - protected int getBodySize() - { - int size = 4; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _messageCount ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchQueueDeleteOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueDeleteOkBodyImpl: "); - buf.append( "messageCount=" ); - buf.append( getMessageCount() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueuePurgeBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueuePurgeBodyImpl.java deleted file mode 100644 index b217a8b3f2..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueuePurgeBodyImpl.java +++ /dev/null @@ -1,141 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueuePurgeBodyImpl extends AMQMethodBody_0_91 implements QueuePurgeBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueuePurgeBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final byte _bitfield0; // [nowait] - - // Constructor - public QueuePurgeBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public QueuePurgeBodyImpl( - int ticket, - AMQShortString queue, - boolean nowait - ) - { - _ticket = ticket; - _queue = queue; - byte bitfield0 = (byte)0; - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchQueuePurge(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueuePurgeBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueuePurgeOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueuePurgeOkBodyImpl.java deleted file mode 100644 index 268ebcff54..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueuePurgeOkBodyImpl.java +++ /dev/null @@ -1,111 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueuePurgeOkBodyImpl extends AMQMethodBody_0_91 implements QueuePurgeOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueuePurgeOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final long _messageCount; // [messageCount] - - // Constructor - public QueuePurgeOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _messageCount = readUnsignedInteger( buffer ); - } - - public QueuePurgeOkBodyImpl( - long messageCount - ) - { - _messageCount = messageCount; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getMessageCount() - { - return _messageCount; - } - - protected int getBodySize() - { - int size = 4; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _messageCount ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchQueuePurgeOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueuePurgeOkBodyImpl: "); - buf.append( "messageCount=" ); - buf.append( getMessageCount() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueUnbindBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueUnbindBodyImpl.java deleted file mode 100644 index d29db36ffa..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueUnbindBodyImpl.java +++ /dev/null @@ -1,163 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueUnbindBodyImpl extends AMQMethodBody_0_91 implements QueueUnbindBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueUnbindBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 50; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final FieldTable _arguments; // [arguments] - - // Constructor - public QueueUnbindBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _arguments = readFieldTable( buffer ); - } - - public QueueUnbindBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString exchange, - AMQShortString routingKey, - FieldTable arguments - ) - { - _ticket = ticket; - _queue = queue; - _exchange = exchange; - _routingKey = routingKey; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _queue ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchQueueUnbind(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueUnbindBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueUnbindOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueUnbindOkBodyImpl.java deleted file mode 100644 index 01747fa536..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/QueueUnbindOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueUnbindOkBodyImpl extends AMQMethodBody_0_91 implements QueueUnbindOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueUnbindOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 51; - - // Fields declared in specification - - // Constructor - public QueueUnbindOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public QueueUnbindOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchQueueUnbindOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueUnbindOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ServerMethodDispatcher_0_91.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ServerMethodDispatcher_0_91.java deleted file mode 100644 index b24b8253d2..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/ServerMethodDispatcher_0_91.java +++ /dev/null @@ -1,69 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.*; - - -public interface ServerMethodDispatcher_0_91 extends ServerMethodDispatcher -{ - - public boolean dispatchBasicAck(BasicAckBody body, int channelId) throws AMQException; - public boolean dispatchBasicCancel(BasicCancelBody body, int channelId) throws AMQException; - public boolean dispatchBasicConsume(BasicConsumeBody body, int channelId) throws AMQException; - public boolean dispatchBasicGet(BasicGetBody body, int channelId) throws AMQException; - public boolean dispatchBasicPublish(BasicPublishBody body, int channelId) throws AMQException; - public boolean dispatchBasicQos(BasicQosBody body, int channelId) throws AMQException; - public boolean dispatchBasicRecover(BasicRecoverBody body, int channelId) throws AMQException; - public boolean dispatchBasicRecoverSync(BasicRecoverSyncBody body, int channelId) throws AMQException; - public boolean dispatchBasicReject(BasicRejectBody body, int channelId) throws AMQException; - public boolean dispatchChannelClose(ChannelCloseBody body, int channelId) throws AMQException; - public boolean dispatchChannelCloseOk(ChannelCloseOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelFlow(ChannelFlowBody body, int channelId) throws AMQException; - public boolean dispatchChannelFlowOk(ChannelFlowOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelOpen(ChannelOpenBody body, int channelId) throws AMQException; - public boolean dispatchConnectionClose(ConnectionCloseBody body, int channelId) throws AMQException; - public boolean dispatchConnectionCloseOk(ConnectionCloseOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionOpen(ConnectionOpenBody body, int channelId) throws AMQException; - public boolean dispatchConnectionSecureOk(ConnectionSecureOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionStartOk(ConnectionStartOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionTuneOk(ConnectionTuneOkBody body, int channelId) throws AMQException; - public boolean dispatchExchangeBound(ExchangeBoundBody body, int channelId) throws AMQException; - public boolean dispatchExchangeDeclare(ExchangeDeclareBody body, int channelId) throws AMQException; - public boolean dispatchExchangeDelete(ExchangeDeleteBody body, int channelId) throws AMQException; - public boolean dispatchQueueBind(QueueBindBody body, int channelId) throws AMQException; - public boolean dispatchQueueDeclare(QueueDeclareBody body, int channelId) throws AMQException; - public boolean dispatchQueueDelete(QueueDeleteBody body, int channelId) throws AMQException; - public boolean dispatchQueuePurge(QueuePurgeBody body, int channelId) throws AMQException; - public boolean dispatchQueueUnbind(QueueUnbindBody body, int channelId) throws AMQException; - public boolean dispatchTxCommit(TxCommitBody body, int channelId) throws AMQException; - public boolean dispatchTxRollback(TxRollbackBody body, int channelId) throws AMQException; - public boolean dispatchTxSelect(TxSelectBody body, int channelId) throws AMQException; - -}
\ No newline at end of file diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxCommitBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxCommitBodyImpl.java deleted file mode 100644 index 8e2427efc4..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxCommitBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxCommitBodyImpl extends AMQMethodBody_0_91 implements TxCommitBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxCommitBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 20; - - // Fields declared in specification - - // Constructor - public TxCommitBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxCommitBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchTxCommit(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxCommitBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxCommitOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxCommitOkBodyImpl.java deleted file mode 100644 index df7af95c0f..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxCommitOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxCommitOkBodyImpl extends AMQMethodBody_0_91 implements TxCommitOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxCommitOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 21; - - // Fields declared in specification - - // Constructor - public TxCommitOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxCommitOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchTxCommitOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxCommitOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxRollbackBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxRollbackBodyImpl.java deleted file mode 100644 index 3b3e1d5366..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxRollbackBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxRollbackBodyImpl extends AMQMethodBody_0_91 implements TxRollbackBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxRollbackBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 30; - - // Fields declared in specification - - // Constructor - public TxRollbackBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxRollbackBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchTxRollback(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxRollbackBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxRollbackOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxRollbackOkBodyImpl.java deleted file mode 100644 index 0d820a4b82..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxRollbackOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxRollbackOkBodyImpl extends AMQMethodBody_0_91 implements TxRollbackOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxRollbackOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 31; - - // Fields declared in specification - - // Constructor - public TxRollbackOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxRollbackOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchTxRollbackOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxRollbackOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxSelectBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxSelectBodyImpl.java deleted file mode 100644 index ad0fe78e9a..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxSelectBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxSelectBodyImpl extends AMQMethodBody_0_91 implements TxSelectBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxSelectBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 10; - - // Fields declared in specification - - // Constructor - public TxSelectBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxSelectBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchTxSelect(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxSelectBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxSelectOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxSelectOkBodyImpl.java deleted file mode 100644 index bfc6296b24..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_0_91/TxSelectOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 0-91 - */ - -package org.apache.qpid.framing.amqp_0_91; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxSelectOkBodyImpl extends AMQMethodBody_0_91 implements TxSelectOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxSelectOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public TxSelectOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxSelectOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_0_91)dispatcher).dispatchTxSelectOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxSelectOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/AMQMethodBody_8_0.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/AMQMethodBody_8_0.java deleted file mode 100644 index 35645854c0..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/AMQMethodBody_8_0.java +++ /dev/null @@ -1,40 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -package org.apache.qpid.framing.amqp_8_0; - -public abstract class AMQMethodBody_8_0 extends org.apache.qpid.framing.AMQMethodBodyImpl -{ - - public byte getMajor() - { - return 8; - } - - public byte getMinor() - { - return 0; - } - - - - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/AccessRequestBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/AccessRequestBodyImpl.java deleted file mode 100644 index a29363f293..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/AccessRequestBodyImpl.java +++ /dev/null @@ -1,181 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class AccessRequestBodyImpl extends AMQMethodBody_8_0 implements AccessRequestBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new AccessRequestBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 30; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final AMQShortString _realm; // [realm] - private final byte _bitfield0; // [exclusive, passive, active, write, read] - - // Constructor - public AccessRequestBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _realm = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public AccessRequestBodyImpl( - AMQShortString realm, - boolean exclusive, - boolean passive, - boolean active, - boolean write, - boolean read - ) - { - _realm = realm; - byte bitfield0 = (byte)0; - if( exclusive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( passive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( active ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - if( write ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); - } - - if( read ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 4)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getRealm() - { - return _realm; - } - public final boolean getExclusive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getPassive() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getActive() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final boolean getWrite() - { - return (((int)(_bitfield0)) & ( 1 << 3)) != 0; - } - public final boolean getRead() - { - return (((int)(_bitfield0)) & ( 1 << 4)) != 0; - } - - protected int getBodySize() - { - int size = 1; - size += getSizeOf( _realm ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _realm ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchAccessRequest(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[AccessRequestBodyImpl: "); - buf.append( "realm=" ); - buf.append( getRealm() ); - buf.append( ", " ); - buf.append( "exclusive=" ); - buf.append( getExclusive() ); - buf.append( ", " ); - buf.append( "passive=" ); - buf.append( getPassive() ); - buf.append( ", " ); - buf.append( "active=" ); - buf.append( getActive() ); - buf.append( ", " ); - buf.append( "write=" ); - buf.append( getWrite() ); - buf.append( ", " ); - buf.append( "read=" ); - buf.append( getRead() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/AccessRequestOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/AccessRequestOkBodyImpl.java deleted file mode 100644 index 5c207b59d4..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/AccessRequestOkBodyImpl.java +++ /dev/null @@ -1,111 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class AccessRequestOkBodyImpl extends AMQMethodBody_8_0 implements AccessRequestOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new AccessRequestOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 30; - public static final int METHOD_ID = 11; - - // Fields declared in specification - private final int _ticket; // [ticket] - - // Constructor - public AccessRequestOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - } - - public AccessRequestOkBodyImpl( - int ticket - ) - { - _ticket = ticket; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - - protected int getBodySize() - { - int size = 2; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchAccessRequestOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[AccessRequestOkBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicAckBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicAckBodyImpl.java deleted file mode 100644 index 81f84ecf7f..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicAckBodyImpl.java +++ /dev/null @@ -1,128 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicAckBodyImpl extends AMQMethodBody_8_0 implements BasicAckBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicAckBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 80; - - // Fields declared in specification - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [multiple] - - // Constructor - public BasicAckBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicAckBodyImpl( - long deliveryTag, - boolean multiple - ) - { - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( multiple ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getMultiple() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 9; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicAck(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicAckBodyImpl: "); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "multiple=" ); - buf.append( getMultiple() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicCancelBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicCancelBodyImpl.java deleted file mode 100644 index 196268654b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicCancelBodyImpl.java +++ /dev/null @@ -1,129 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicCancelBodyImpl extends AMQMethodBody_8_0 implements BasicCancelBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicCancelBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [nowait] - - // Constructor - public BasicCancelBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicCancelBodyImpl( - AMQShortString consumerTag, - boolean nowait - ) - { - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicCancel(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicCancelBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicCancelOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicCancelOkBodyImpl.java deleted file mode 100644 index 082348616d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicCancelOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicCancelOkBodyImpl extends AMQMethodBody_8_0 implements BasicCancelOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicCancelOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public BasicCancelOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public BasicCancelOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicCancelOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicCancelOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicConsumeBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicConsumeBodyImpl.java deleted file mode 100644 index d11f18986f..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicConsumeBodyImpl.java +++ /dev/null @@ -1,207 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicConsumeBodyImpl extends AMQMethodBody_8_0 implements BasicConsumeBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicConsumeBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [noLocal, noAck, exclusive, nowait] - private final FieldTable _arguments; // [arguments] - - // Constructor - public BasicConsumeBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _arguments = readFieldTable( buffer ); - } - - public BasicConsumeBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString consumerTag, - boolean noLocal, - boolean noAck, - boolean exclusive, - boolean nowait, - FieldTable arguments - ) - { - _ticket = ticket; - _queue = queue; - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( noLocal ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( noAck ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( exclusive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); - } - - _bitfield0 = bitfield0; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNoLocal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getNoAck() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getExclusive() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 3)) != 0; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _consumerTag ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicConsume(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicConsumeBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "noLocal=" ); - buf.append( getNoLocal() ); - buf.append( ", " ); - buf.append( "noAck=" ); - buf.append( getNoAck() ); - buf.append( ", " ); - buf.append( "exclusive=" ); - buf.append( getExclusive() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicConsumeOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicConsumeOkBodyImpl.java deleted file mode 100644 index 7327b2da3f..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicConsumeOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicConsumeOkBodyImpl extends AMQMethodBody_8_0 implements BasicConsumeOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicConsumeOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public BasicConsumeOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public BasicConsumeOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicConsumeOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicConsumeOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicDeliverBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicDeliverBodyImpl.java deleted file mode 100644 index 58cf16fe55..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicDeliverBodyImpl.java +++ /dev/null @@ -1,168 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicDeliverBodyImpl extends AMQMethodBody_8_0 implements BasicDeliverBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicDeliverBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 60; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [redelivered] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - - // Constructor - public BasicDeliverBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - } - - public BasicDeliverBodyImpl( - AMQShortString consumerTag, - long deliveryTag, - boolean redelivered, - AMQShortString exchange, - AMQShortString routingKey - ) - { - _consumerTag = consumerTag; - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( redelivered ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - _bitfield0 = bitfield0; - _exchange = exchange; - _routingKey = routingKey; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getRedelivered() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - - protected int getBodySize() - { - int size = 9; - size += getSizeOf( _consumerTag ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicDeliver(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicDeliverBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "redelivered=" ); - buf.append( getRedelivered() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicGetBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicGetBodyImpl.java deleted file mode 100644 index d348101cee..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicGetBodyImpl.java +++ /dev/null @@ -1,141 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicGetBodyImpl extends AMQMethodBody_8_0 implements BasicGetBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicGetBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 70; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final byte _bitfield0; // [noAck] - - // Constructor - public BasicGetBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicGetBodyImpl( - int ticket, - AMQShortString queue, - boolean noAck - ) - { - _ticket = ticket; - _queue = queue; - byte bitfield0 = (byte)0; - if( noAck ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final boolean getNoAck() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicGet(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicGetBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "noAck=" ); - buf.append( getNoAck() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicGetEmptyBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicGetEmptyBodyImpl.java deleted file mode 100644 index 3e49be1eb1..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicGetEmptyBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicGetEmptyBodyImpl extends AMQMethodBody_8_0 implements BasicGetEmptyBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicGetEmptyBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 72; - - // Fields declared in specification - private final AMQShortString _clusterId; // [clusterId] - - // Constructor - public BasicGetEmptyBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _clusterId = readAMQShortString( buffer ); - } - - public BasicGetEmptyBodyImpl( - AMQShortString clusterId - ) - { - _clusterId = clusterId; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getClusterId() - { - return _clusterId; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _clusterId ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _clusterId ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicGetEmpty(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicGetEmptyBodyImpl: "); - buf.append( "clusterId=" ); - buf.append( getClusterId() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicGetOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicGetOkBodyImpl.java deleted file mode 100644 index bcfefe2e34..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicGetOkBodyImpl.java +++ /dev/null @@ -1,167 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicGetOkBodyImpl extends AMQMethodBody_8_0 implements BasicGetOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicGetOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 71; - - // Fields declared in specification - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [redelivered] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final long _messageCount; // [messageCount] - - // Constructor - public BasicGetOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _messageCount = readUnsignedInteger( buffer ); - } - - public BasicGetOkBodyImpl( - long deliveryTag, - boolean redelivered, - AMQShortString exchange, - AMQShortString routingKey, - long messageCount - ) - { - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( redelivered ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - _bitfield0 = bitfield0; - _exchange = exchange; - _routingKey = routingKey; - _messageCount = messageCount; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getRedelivered() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final long getMessageCount() - { - return _messageCount; - } - - protected int getBodySize() - { - int size = 13; - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeUnsignedInteger( buffer, _messageCount ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicGetOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicGetOkBodyImpl: "); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "redelivered=" ); - buf.append( getRedelivered() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "messageCount=" ); - buf.append( getMessageCount() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicPublishBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicPublishBodyImpl.java deleted file mode 100644 index dc5d82a5b4..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicPublishBodyImpl.java +++ /dev/null @@ -1,167 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicPublishBodyImpl extends AMQMethodBody_8_0 implements BasicPublishBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicPublishBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final byte _bitfield0; // [mandatory, immediate] - - // Constructor - public BasicPublishBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicPublishBodyImpl( - int ticket, - AMQShortString exchange, - AMQShortString routingKey, - boolean mandatory, - boolean immediate - ) - { - _ticket = ticket; - _exchange = exchange; - _routingKey = routingKey; - byte bitfield0 = (byte)0; - if( mandatory ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( immediate ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final boolean getMandatory() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getImmediate() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicPublish(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicPublishBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "mandatory=" ); - buf.append( getMandatory() ); - buf.append( ", " ); - buf.append( "immediate=" ); - buf.append( getImmediate() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicQosBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicQosBodyImpl.java deleted file mode 100644 index 76fdfac3cd..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicQosBodyImpl.java +++ /dev/null @@ -1,140 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicQosBodyImpl extends AMQMethodBody_8_0 implements BasicQosBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicQosBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final long _prefetchSize; // [prefetchSize] - private final int _prefetchCount; // [prefetchCount] - private final byte _bitfield0; // [global] - - // Constructor - public BasicQosBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _prefetchSize = readUnsignedInteger( buffer ); - _prefetchCount = readUnsignedShort( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicQosBodyImpl( - long prefetchSize, - int prefetchCount, - boolean global - ) - { - _prefetchSize = prefetchSize; - _prefetchCount = prefetchCount; - byte bitfield0 = (byte)0; - if( global ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getPrefetchSize() - { - return _prefetchSize; - } - public final int getPrefetchCount() - { - return _prefetchCount; - } - public final boolean getGlobal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 7; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _prefetchSize ); - writeUnsignedShort( buffer, _prefetchCount ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicQos(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicQosBodyImpl: "); - buf.append( "prefetchSize=" ); - buf.append( getPrefetchSize() ); - buf.append( ", " ); - buf.append( "prefetchCount=" ); - buf.append( getPrefetchCount() ); - buf.append( ", " ); - buf.append( "global=" ); - buf.append( getGlobal() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicQosOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicQosOkBodyImpl.java deleted file mode 100644 index a9d7ca998c..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicQosOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicQosOkBodyImpl extends AMQMethodBody_8_0 implements BasicQosOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicQosOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public BasicQosOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public BasicQosOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicQosOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicQosOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicRecoverBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicRecoverBodyImpl.java deleted file mode 100644 index 2ad62004bc..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicRecoverBodyImpl.java +++ /dev/null @@ -1,116 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicRecoverBodyImpl extends AMQMethodBody_8_0 implements BasicRecoverBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicRecoverBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 100; - - // Fields declared in specification - private final byte _bitfield0; // [requeue] - - // Constructor - public BasicRecoverBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _bitfield0 = readBitfield( buffer ); - } - - public BasicRecoverBodyImpl( - boolean requeue - ) - { - byte bitfield0 = (byte)0; - if( requeue ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final boolean getRequeue() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicRecover(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicRecoverBodyImpl: "); - buf.append( "requeue=" ); - buf.append( getRequeue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicRecoverOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicRecoverOkBodyImpl.java deleted file mode 100644 index 4d247b7edd..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicRecoverOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicRecoverOkBodyImpl extends AMQMethodBody_8_0 implements BasicRecoverOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicRecoverOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 101; - - // Fields declared in specification - - // Constructor - public BasicRecoverOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public BasicRecoverOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicRecoverOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicRecoverOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicRejectBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicRejectBodyImpl.java deleted file mode 100644 index b1ae381f12..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicRejectBodyImpl.java +++ /dev/null @@ -1,128 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicRejectBodyImpl extends AMQMethodBody_8_0 implements BasicRejectBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicRejectBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 90; - - // Fields declared in specification - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [requeue] - - // Constructor - public BasicRejectBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public BasicRejectBodyImpl( - long deliveryTag, - boolean requeue - ) - { - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( requeue ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getRequeue() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 9; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicReject(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicRejectBodyImpl: "); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "requeue=" ); - buf.append( getRequeue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicReturnBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicReturnBodyImpl.java deleted file mode 100644 index 9675aec1a1..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/BasicReturnBodyImpl.java +++ /dev/null @@ -1,150 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class BasicReturnBodyImpl extends AMQMethodBody_8_0 implements BasicReturnBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new BasicReturnBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 60; - public static final int METHOD_ID = 50; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - - // Constructor - public BasicReturnBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - } - - public BasicReturnBodyImpl( - int replyCode, - AMQShortString replyText, - AMQShortString exchange, - AMQShortString routingKey - ) - { - _replyCode = replyCode; - _replyText = replyText; - _exchange = exchange; - _routingKey = routingKey; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _replyText ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchBasicReturn(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[BasicReturnBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelAlertBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelAlertBodyImpl.java deleted file mode 100644 index eecd44b026..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelAlertBodyImpl.java +++ /dev/null @@ -1,137 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelAlertBodyImpl extends AMQMethodBody_8_0 implements ChannelAlertBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelAlertBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final FieldTable _details; // [details] - - // Constructor - public ChannelAlertBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _details = readFieldTable( buffer ); - } - - public ChannelAlertBodyImpl( - int replyCode, - AMQShortString replyText, - FieldTable details - ) - { - _replyCode = replyCode; - _replyText = replyText; - _details = details; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final FieldTable getDetails() - { - return _details; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _replyText ); - size += getSizeOf( _details ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeFieldTable( buffer, _details ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchChannelAlert(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelAlertBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "details=" ); - buf.append( getDetails() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelCloseBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelCloseBodyImpl.java deleted file mode 100644 index dccb691dc8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelCloseBodyImpl.java +++ /dev/null @@ -1,148 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelCloseBodyImpl extends AMQMethodBody_8_0 implements ChannelCloseBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelCloseBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final int _classId; // [classId] - private final int _methodId; // [methodId] - - // Constructor - public ChannelCloseBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _classId = readUnsignedShort( buffer ); - _methodId = readUnsignedShort( buffer ); - } - - public ChannelCloseBodyImpl( - int replyCode, - AMQShortString replyText, - int classId, - int methodId - ) - { - _replyCode = replyCode; - _replyText = replyText; - _classId = classId; - _methodId = methodId; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final int getClassId() - { - return _classId; - } - public final int getMethodId() - { - return _methodId; - } - - protected int getBodySize() - { - int size = 6; - size += getSizeOf( _replyText ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeUnsignedShort( buffer, _classId ); - writeUnsignedShort( buffer, _methodId ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchChannelClose(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelCloseBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "classId=" ); - buf.append( getClassId() ); - buf.append( ", " ); - buf.append( "methodId=" ); - buf.append( getMethodId() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelCloseOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelCloseOkBodyImpl.java deleted file mode 100644 index ed3eab5da9..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelCloseOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelCloseOkBodyImpl extends AMQMethodBody_8_0 implements ChannelCloseOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelCloseOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 41; - - // Fields declared in specification - - // Constructor - public ChannelCloseOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ChannelCloseOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchChannelCloseOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelCloseOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelFlowBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelFlowBodyImpl.java deleted file mode 100644 index 12886543cf..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelFlowBodyImpl.java +++ /dev/null @@ -1,116 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelFlowBodyImpl extends AMQMethodBody_8_0 implements ChannelFlowBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelFlowBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final byte _bitfield0; // [active] - - // Constructor - public ChannelFlowBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _bitfield0 = readBitfield( buffer ); - } - - public ChannelFlowBodyImpl( - boolean active - ) - { - byte bitfield0 = (byte)0; - if( active ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final boolean getActive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchChannelFlow(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelFlowBodyImpl: "); - buf.append( "active=" ); - buf.append( getActive() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelFlowOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelFlowOkBodyImpl.java deleted file mode 100644 index 8b6ae9c444..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelFlowOkBodyImpl.java +++ /dev/null @@ -1,116 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelFlowOkBodyImpl extends AMQMethodBody_8_0 implements ChannelFlowOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelFlowOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final byte _bitfield0; // [active] - - // Constructor - public ChannelFlowOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _bitfield0 = readBitfield( buffer ); - } - - public ChannelFlowOkBodyImpl( - boolean active - ) - { - byte bitfield0 = (byte)0; - if( active ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final boolean getActive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchChannelFlowOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelFlowOkBodyImpl: "); - buf.append( "active=" ); - buf.append( getActive() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelOpenBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelOpenBodyImpl.java deleted file mode 100644 index c4dab6343d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelOpenBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelOpenBodyImpl extends AMQMethodBody_8_0 implements ChannelOpenBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelOpenBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final AMQShortString _outOfBand; // [outOfBand] - - // Constructor - public ChannelOpenBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _outOfBand = readAMQShortString( buffer ); - } - - public ChannelOpenBodyImpl( - AMQShortString outOfBand - ) - { - _outOfBand = outOfBand; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getOutOfBand() - { - return _outOfBand; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _outOfBand ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _outOfBand ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchChannelOpen(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelOpenBodyImpl: "); - buf.append( "outOfBand=" ); - buf.append( getOutOfBand() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelOpenOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelOpenOkBodyImpl.java deleted file mode 100644 index f84a0c314d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ChannelOpenOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ChannelOpenOkBodyImpl extends AMQMethodBody_8_0 implements ChannelOpenOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ChannelOpenOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 20; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public ChannelOpenOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ChannelOpenOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchChannelOpenOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ChannelOpenOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ClientMethodDispatcher_8_0.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ClientMethodDispatcher_8_0.java deleted file mode 100644 index 52e44a8e4d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ClientMethodDispatcher_8_0.java +++ /dev/null @@ -1,92 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.*; - -public interface ClientMethodDispatcher_8_0 extends ClientMethodDispatcher -{ - - public boolean dispatchAccessRequestOk(AccessRequestOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicCancelOk(BasicCancelOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicConsumeOk(BasicConsumeOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicDeliver(BasicDeliverBody body, int channelId) throws AMQException; - public boolean dispatchBasicGetEmpty(BasicGetEmptyBody body, int channelId) throws AMQException; - public boolean dispatchBasicGetOk(BasicGetOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicQosOk(BasicQosOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicRecoverOk(BasicRecoverOkBody body, int channelId) throws AMQException; - public boolean dispatchBasicReturn(BasicReturnBody body, int channelId) throws AMQException; - public boolean dispatchChannelAlert(ChannelAlertBody body, int channelId) throws AMQException; - public boolean dispatchChannelClose(ChannelCloseBody body, int channelId) throws AMQException; - public boolean dispatchChannelCloseOk(ChannelCloseOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelFlow(ChannelFlowBody body, int channelId) throws AMQException; - public boolean dispatchChannelFlowOk(ChannelFlowOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelOpenOk(ChannelOpenOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionClose(ConnectionCloseBody body, int channelId) throws AMQException; - public boolean dispatchConnectionCloseOk(ConnectionCloseOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionOpenOk(ConnectionOpenOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionRedirect(ConnectionRedirectBody body, int channelId) throws AMQException; - public boolean dispatchConnectionSecure(ConnectionSecureBody body, int channelId) throws AMQException; - public boolean dispatchConnectionStart(ConnectionStartBody body, int channelId) throws AMQException; - public boolean dispatchConnectionTune(ConnectionTuneBody body, int channelId) throws AMQException; - public boolean dispatchDtxSelectOk(DtxSelectOkBody body, int channelId) throws AMQException; - public boolean dispatchDtxStartOk(DtxStartOkBody body, int channelId) throws AMQException; - public boolean dispatchExchangeBoundOk(ExchangeBoundOkBody body, int channelId) throws AMQException; - public boolean dispatchExchangeDeclareOk(ExchangeDeclareOkBody body, int channelId) throws AMQException; - public boolean dispatchExchangeDeleteOk(ExchangeDeleteOkBody body, int channelId) throws AMQException; - public boolean dispatchFileCancelOk(FileCancelOkBody body, int channelId) throws AMQException; - public boolean dispatchFileConsumeOk(FileConsumeOkBody body, int channelId) throws AMQException; - public boolean dispatchFileDeliver(FileDeliverBody body, int channelId) throws AMQException; - public boolean dispatchFileOpen(FileOpenBody body, int channelId) throws AMQException; - public boolean dispatchFileOpenOk(FileOpenOkBody body, int channelId) throws AMQException; - public boolean dispatchFileQosOk(FileQosOkBody body, int channelId) throws AMQException; - public boolean dispatchFileReturn(FileReturnBody body, int channelId) throws AMQException; - public boolean dispatchFileStage(FileStageBody body, int channelId) throws AMQException; - public boolean dispatchQueueBindOk(QueueBindOkBody body, int channelId) throws AMQException; - public boolean dispatchQueueDeclareOk(QueueDeclareOkBody body, int channelId) throws AMQException; - public boolean dispatchQueueDeleteOk(QueueDeleteOkBody body, int channelId) throws AMQException; - public boolean dispatchQueuePurgeOk(QueuePurgeOkBody body, int channelId) throws AMQException; - public boolean dispatchStreamCancelOk(StreamCancelOkBody body, int channelId) throws AMQException; - public boolean dispatchStreamConsumeOk(StreamConsumeOkBody body, int channelId) throws AMQException; - public boolean dispatchStreamDeliver(StreamDeliverBody body, int channelId) throws AMQException; - public boolean dispatchStreamQosOk(StreamQosOkBody body, int channelId) throws AMQException; - public boolean dispatchStreamReturn(StreamReturnBody body, int channelId) throws AMQException; - public boolean dispatchTestContent(TestContentBody body, int channelId) throws AMQException; - public boolean dispatchTestContentOk(TestContentOkBody body, int channelId) throws AMQException; - public boolean dispatchTestInteger(TestIntegerBody body, int channelId) throws AMQException; - public boolean dispatchTestIntegerOk(TestIntegerOkBody body, int channelId) throws AMQException; - public boolean dispatchTestString(TestStringBody body, int channelId) throws AMQException; - public boolean dispatchTestStringOk(TestStringOkBody body, int channelId) throws AMQException; - public boolean dispatchTestTable(TestTableBody body, int channelId) throws AMQException; - public boolean dispatchTestTableOk(TestTableOkBody body, int channelId) throws AMQException; - public boolean dispatchTxCommitOk(TxCommitOkBody body, int channelId) throws AMQException; - public boolean dispatchTxRollbackOk(TxRollbackOkBody body, int channelId) throws AMQException; - public boolean dispatchTxSelectOk(TxSelectOkBody body, int channelId) throws AMQException; - -}
\ No newline at end of file diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionCloseBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionCloseBodyImpl.java deleted file mode 100644 index eab4ef05ee..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionCloseBodyImpl.java +++ /dev/null @@ -1,148 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionCloseBodyImpl extends AMQMethodBody_8_0 implements ConnectionCloseBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionCloseBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 60; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final int _classId; // [classId] - private final int _methodId; // [methodId] - - // Constructor - public ConnectionCloseBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _classId = readUnsignedShort( buffer ); - _methodId = readUnsignedShort( buffer ); - } - - public ConnectionCloseBodyImpl( - int replyCode, - AMQShortString replyText, - int classId, - int methodId - ) - { - _replyCode = replyCode; - _replyText = replyText; - _classId = classId; - _methodId = methodId; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final int getClassId() - { - return _classId; - } - public final int getMethodId() - { - return _methodId; - } - - protected int getBodySize() - { - int size = 6; - size += getSizeOf( _replyText ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeUnsignedShort( buffer, _classId ); - writeUnsignedShort( buffer, _methodId ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchConnectionClose(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionCloseBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "classId=" ); - buf.append( getClassId() ); - buf.append( ", " ); - buf.append( "methodId=" ); - buf.append( getMethodId() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionCloseOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionCloseOkBodyImpl.java deleted file mode 100644 index 876715a37b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionCloseOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionCloseOkBodyImpl extends AMQMethodBody_8_0 implements ConnectionCloseOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionCloseOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 61; - - // Fields declared in specification - - // Constructor - public ConnectionCloseOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ConnectionCloseOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchConnectionCloseOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionCloseOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionOpenBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionOpenBodyImpl.java deleted file mode 100644 index 7745a8de0a..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionOpenBodyImpl.java +++ /dev/null @@ -1,142 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionOpenBodyImpl extends AMQMethodBody_8_0 implements ConnectionOpenBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionOpenBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final AMQShortString _virtualHost; // [virtualHost] - private final AMQShortString _capabilities; // [capabilities] - private final byte _bitfield0; // [insist] - - // Constructor - public ConnectionOpenBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _virtualHost = readAMQShortString( buffer ); - _capabilities = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public ConnectionOpenBodyImpl( - AMQShortString virtualHost, - AMQShortString capabilities, - boolean insist - ) - { - _virtualHost = virtualHost; - _capabilities = capabilities; - byte bitfield0 = (byte)0; - if( insist ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getVirtualHost() - { - return _virtualHost; - } - public final AMQShortString getCapabilities() - { - return _capabilities; - } - public final boolean getInsist() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - size += getSizeOf( _virtualHost ); - size += getSizeOf( _capabilities ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _virtualHost ); - writeAMQShortString( buffer, _capabilities ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchConnectionOpen(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionOpenBodyImpl: "); - buf.append( "virtualHost=" ); - buf.append( getVirtualHost() ); - buf.append( ", " ); - buf.append( "capabilities=" ); - buf.append( getCapabilities() ); - buf.append( ", " ); - buf.append( "insist=" ); - buf.append( getInsist() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionOpenOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionOpenOkBodyImpl.java deleted file mode 100644 index b74a2857cd..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionOpenOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionOpenOkBodyImpl extends AMQMethodBody_8_0 implements ConnectionOpenOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionOpenOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 41; - - // Fields declared in specification - private final AMQShortString _knownHosts; // [knownHosts] - - // Constructor - public ConnectionOpenOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _knownHosts = readAMQShortString( buffer ); - } - - public ConnectionOpenOkBodyImpl( - AMQShortString knownHosts - ) - { - _knownHosts = knownHosts; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getKnownHosts() - { - return _knownHosts; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _knownHosts ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _knownHosts ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchConnectionOpenOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionOpenOkBodyImpl: "); - buf.append( "knownHosts=" ); - buf.append( getKnownHosts() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionRedirectBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionRedirectBodyImpl.java deleted file mode 100644 index 59eadf1be3..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionRedirectBodyImpl.java +++ /dev/null @@ -1,125 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionRedirectBodyImpl extends AMQMethodBody_8_0 implements ConnectionRedirectBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionRedirectBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 50; - - // Fields declared in specification - private final AMQShortString _host; // [host] - private final AMQShortString _knownHosts; // [knownHosts] - - // Constructor - public ConnectionRedirectBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _host = readAMQShortString( buffer ); - _knownHosts = readAMQShortString( buffer ); - } - - public ConnectionRedirectBodyImpl( - AMQShortString host, - AMQShortString knownHosts - ) - { - _host = host; - _knownHosts = knownHosts; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getHost() - { - return _host; - } - public final AMQShortString getKnownHosts() - { - return _knownHosts; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _host ); - size += getSizeOf( _knownHosts ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _host ); - writeAMQShortString( buffer, _knownHosts ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchConnectionRedirect(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionRedirectBodyImpl: "); - buf.append( "host=" ); - buf.append( getHost() ); - buf.append( ", " ); - buf.append( "knownHosts=" ); - buf.append( getKnownHosts() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionSecureBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionSecureBodyImpl.java deleted file mode 100644 index 29b341463e..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionSecureBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionSecureBodyImpl extends AMQMethodBody_8_0 implements ConnectionSecureBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionSecureBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final byte[] _challenge; // [challenge] - - // Constructor - public ConnectionSecureBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _challenge = readBytes( buffer ); - } - - public ConnectionSecureBodyImpl( - byte[] challenge - ) - { - _challenge = challenge; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getChallenge() - { - return _challenge; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _challenge ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _challenge ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchConnectionSecure(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionSecureBodyImpl: "); - buf.append( "challenge=" ); - buf.append( getChallenge() == null ? "null" : java.util.Arrays.toString( getChallenge() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionSecureOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionSecureOkBodyImpl.java deleted file mode 100644 index 046abf439c..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionSecureOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionSecureOkBodyImpl extends AMQMethodBody_8_0 implements ConnectionSecureOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionSecureOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final byte[] _response; // [response] - - // Constructor - public ConnectionSecureOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _response = readBytes( buffer ); - } - - public ConnectionSecureOkBodyImpl( - byte[] response - ) - { - _response = response; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getResponse() - { - return _response; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _response ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _response ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchConnectionSecureOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionSecureOkBodyImpl: "); - buf.append( "response=" ); - buf.append( getResponse() == null ? "null" : java.util.Arrays.toString( getResponse() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionStartBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionStartBodyImpl.java deleted file mode 100644 index 1f23a9da6e..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionStartBodyImpl.java +++ /dev/null @@ -1,162 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionStartBodyImpl extends AMQMethodBody_8_0 implements ConnectionStartBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionStartBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final short _versionMajor; // [versionMajor] - private final short _versionMinor; // [versionMinor] - private final FieldTable _serverProperties; // [serverProperties] - private final byte[] _mechanisms; // [mechanisms] - private final byte[] _locales; // [locales] - - // Constructor - public ConnectionStartBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _versionMajor = readUnsignedByte( buffer ); - _versionMinor = readUnsignedByte( buffer ); - _serverProperties = readFieldTable( buffer ); - _mechanisms = readBytes( buffer ); - _locales = readBytes( buffer ); - } - - public ConnectionStartBodyImpl( - short versionMajor, - short versionMinor, - FieldTable serverProperties, - byte[] mechanisms, - byte[] locales - ) - { - _versionMajor = versionMajor; - _versionMinor = versionMinor; - _serverProperties = serverProperties; - _mechanisms = mechanisms; - _locales = locales; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final short getVersionMajor() - { - return _versionMajor; - } - public final short getVersionMinor() - { - return _versionMinor; - } - public final FieldTable getServerProperties() - { - return _serverProperties; - } - public final byte[] getMechanisms() - { - return _mechanisms; - } - public final byte[] getLocales() - { - return _locales; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _serverProperties ); - size += getSizeOf( _mechanisms ); - size += getSizeOf( _locales ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedByte( buffer, _versionMajor ); - writeUnsignedByte( buffer, _versionMinor ); - writeFieldTable( buffer, _serverProperties ); - writeBytes( buffer, _mechanisms ); - writeBytes( buffer, _locales ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchConnectionStart(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionStartBodyImpl: "); - buf.append( "versionMajor=" ); - buf.append( getVersionMajor() ); - buf.append( ", " ); - buf.append( "versionMinor=" ); - buf.append( getVersionMinor() ); - buf.append( ", " ); - buf.append( "serverProperties=" ); - buf.append( getServerProperties() ); - buf.append( ", " ); - buf.append( "mechanisms=" ); - buf.append( getMechanisms() == null ? "null" : java.util.Arrays.toString( getMechanisms() ) ); - buf.append( ", " ); - buf.append( "locales=" ); - buf.append( getLocales() == null ? "null" : java.util.Arrays.toString( getLocales() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionStartOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionStartOkBodyImpl.java deleted file mode 100644 index 24ecf380ac..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionStartOkBodyImpl.java +++ /dev/null @@ -1,151 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionStartOkBodyImpl extends AMQMethodBody_8_0 implements ConnectionStartOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionStartOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 11; - - // Fields declared in specification - private final FieldTable _clientProperties; // [clientProperties] - private final AMQShortString _mechanism; // [mechanism] - private final byte[] _response; // [response] - private final AMQShortString _locale; // [locale] - - // Constructor - public ConnectionStartOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _clientProperties = readFieldTable( buffer ); - _mechanism = readAMQShortString( buffer ); - _response = readBytes( buffer ); - _locale = readAMQShortString( buffer ); - } - - public ConnectionStartOkBodyImpl( - FieldTable clientProperties, - AMQShortString mechanism, - byte[] response, - AMQShortString locale - ) - { - _clientProperties = clientProperties; - _mechanism = mechanism; - _response = response; - _locale = locale; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final FieldTable getClientProperties() - { - return _clientProperties; - } - public final AMQShortString getMechanism() - { - return _mechanism; - } - public final byte[] getResponse() - { - return _response; - } - public final AMQShortString getLocale() - { - return _locale; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _clientProperties ); - size += getSizeOf( _mechanism ); - size += getSizeOf( _response ); - size += getSizeOf( _locale ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeFieldTable( buffer, _clientProperties ); - writeAMQShortString( buffer, _mechanism ); - writeBytes( buffer, _response ); - writeAMQShortString( buffer, _locale ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchConnectionStartOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionStartOkBodyImpl: "); - buf.append( "clientProperties=" ); - buf.append( getClientProperties() ); - buf.append( ", " ); - buf.append( "mechanism=" ); - buf.append( getMechanism() ); - buf.append( ", " ); - buf.append( "response=" ); - buf.append( getResponse() == null ? "null" : java.util.Arrays.toString( getResponse() ) ); - buf.append( ", " ); - buf.append( "locale=" ); - buf.append( getLocale() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionTuneBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionTuneBodyImpl.java deleted file mode 100644 index 83aff93055..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionTuneBodyImpl.java +++ /dev/null @@ -1,135 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionTuneBodyImpl extends AMQMethodBody_8_0 implements ConnectionTuneBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionTuneBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final int _channelMax; // [channelMax] - private final long _frameMax; // [frameMax] - private final int _heartbeat; // [heartbeat] - - // Constructor - public ConnectionTuneBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _channelMax = readUnsignedShort( buffer ); - _frameMax = readUnsignedInteger( buffer ); - _heartbeat = readUnsignedShort( buffer ); - } - - public ConnectionTuneBodyImpl( - int channelMax, - long frameMax, - int heartbeat - ) - { - _channelMax = channelMax; - _frameMax = frameMax; - _heartbeat = heartbeat; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getChannelMax() - { - return _channelMax; - } - public final long getFrameMax() - { - return _frameMax; - } - public final int getHeartbeat() - { - return _heartbeat; - } - - protected int getBodySize() - { - int size = 8; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _channelMax ); - writeUnsignedInteger( buffer, _frameMax ); - writeUnsignedShort( buffer, _heartbeat ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchConnectionTune(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionTuneBodyImpl: "); - buf.append( "channelMax=" ); - buf.append( getChannelMax() ); - buf.append( ", " ); - buf.append( "frameMax=" ); - buf.append( getFrameMax() ); - buf.append( ", " ); - buf.append( "heartbeat=" ); - buf.append( getHeartbeat() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionTuneOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionTuneOkBodyImpl.java deleted file mode 100644 index a6221b9815..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ConnectionTuneOkBodyImpl.java +++ /dev/null @@ -1,135 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ConnectionTuneOkBodyImpl extends AMQMethodBody_8_0 implements ConnectionTuneOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ConnectionTuneOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 10; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final int _channelMax; // [channelMax] - private final long _frameMax; // [frameMax] - private final int _heartbeat; // [heartbeat] - - // Constructor - public ConnectionTuneOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _channelMax = readUnsignedShort( buffer ); - _frameMax = readUnsignedInteger( buffer ); - _heartbeat = readUnsignedShort( buffer ); - } - - public ConnectionTuneOkBodyImpl( - int channelMax, - long frameMax, - int heartbeat - ) - { - _channelMax = channelMax; - _frameMax = frameMax; - _heartbeat = heartbeat; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getChannelMax() - { - return _channelMax; - } - public final long getFrameMax() - { - return _frameMax; - } - public final int getHeartbeat() - { - return _heartbeat; - } - - protected int getBodySize() - { - int size = 8; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _channelMax ); - writeUnsignedInteger( buffer, _frameMax ); - writeUnsignedShort( buffer, _heartbeat ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchConnectionTuneOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ConnectionTuneOkBodyImpl: "); - buf.append( "channelMax=" ); - buf.append( getChannelMax() ); - buf.append( ", " ); - buf.append( "frameMax=" ); - buf.append( getFrameMax() ); - buf.append( ", " ); - buf.append( "heartbeat=" ); - buf.append( getHeartbeat() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/DtxSelectBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/DtxSelectBodyImpl.java deleted file mode 100644 index ac2ff8b225..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/DtxSelectBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class DtxSelectBodyImpl extends AMQMethodBody_8_0 implements DtxSelectBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new DtxSelectBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 100; - public static final int METHOD_ID = 10; - - // Fields declared in specification - - // Constructor - public DtxSelectBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public DtxSelectBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchDtxSelect(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[DtxSelectBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/DtxSelectOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/DtxSelectOkBodyImpl.java deleted file mode 100644 index 2281853e00..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/DtxSelectOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class DtxSelectOkBodyImpl extends AMQMethodBody_8_0 implements DtxSelectOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new DtxSelectOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 100; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public DtxSelectOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public DtxSelectOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchDtxSelectOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[DtxSelectOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/DtxStartBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/DtxStartBodyImpl.java deleted file mode 100644 index b5a1faa760..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/DtxStartBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class DtxStartBodyImpl extends AMQMethodBody_8_0 implements DtxStartBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new DtxStartBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 100; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final AMQShortString _dtxIdentifier; // [dtxIdentifier] - - // Constructor - public DtxStartBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _dtxIdentifier = readAMQShortString( buffer ); - } - - public DtxStartBodyImpl( - AMQShortString dtxIdentifier - ) - { - _dtxIdentifier = dtxIdentifier; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getDtxIdentifier() - { - return _dtxIdentifier; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _dtxIdentifier ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _dtxIdentifier ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchDtxStart(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[DtxStartBodyImpl: "); - buf.append( "dtxIdentifier=" ); - buf.append( getDtxIdentifier() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/DtxStartOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/DtxStartOkBodyImpl.java deleted file mode 100644 index 73fd13e7d3..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/DtxStartOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class DtxStartOkBodyImpl extends AMQMethodBody_8_0 implements DtxStartOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new DtxStartOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 100; - public static final int METHOD_ID = 21; - - // Fields declared in specification - - // Constructor - public DtxStartOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public DtxStartOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchDtxStartOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[DtxStartOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeBoundBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeBoundBodyImpl.java deleted file mode 100644 index c391f1b7ee..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeBoundBodyImpl.java +++ /dev/null @@ -1,138 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeBoundBodyImpl extends AMQMethodBody_8_0 implements ExchangeBoundBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeBoundBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 22; - - // Fields declared in specification - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final AMQShortString _queue; // [queue] - - // Constructor - public ExchangeBoundBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _queue = readAMQShortString( buffer ); - } - - public ExchangeBoundBodyImpl( - AMQShortString exchange, - AMQShortString routingKey, - AMQShortString queue - ) - { - _exchange = exchange; - _routingKey = routingKey; - _queue = queue; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final AMQShortString getQueue() - { - return _queue; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeAMQShortString( buffer, _queue ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchExchangeBound(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeBoundBodyImpl: "); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeBoundOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeBoundOkBodyImpl.java deleted file mode 100644 index cfbe77d70e..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeBoundOkBodyImpl.java +++ /dev/null @@ -1,124 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeBoundOkBodyImpl extends AMQMethodBody_8_0 implements ExchangeBoundOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeBoundOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 23; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - - // Constructor - public ExchangeBoundOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - } - - public ExchangeBoundOkBodyImpl( - int replyCode, - AMQShortString replyText - ) - { - _replyCode = replyCode; - _replyText = replyText; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _replyText ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchExchangeBoundOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeBoundOkBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeDeclareBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeDeclareBodyImpl.java deleted file mode 100644 index de47e0b867..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeDeclareBodyImpl.java +++ /dev/null @@ -1,220 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeDeclareBodyImpl extends AMQMethodBody_8_0 implements ExchangeDeclareBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeDeclareBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _type; // [type] - private final byte _bitfield0; // [passive, durable, autoDelete, internal, nowait] - private final FieldTable _arguments; // [arguments] - - // Constructor - public ExchangeDeclareBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _exchange = readAMQShortString( buffer ); - _type = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _arguments = readFieldTable( buffer ); - } - - public ExchangeDeclareBodyImpl( - int ticket, - AMQShortString exchange, - AMQShortString type, - boolean passive, - boolean durable, - boolean autoDelete, - boolean internal, - boolean nowait, - FieldTable arguments - ) - { - _ticket = ticket; - _exchange = exchange; - _type = type; - byte bitfield0 = (byte)0; - if( passive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( durable ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( autoDelete ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - if( internal ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 4)); - } - - _bitfield0 = bitfield0; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getType() - { - return _type; - } - public final boolean getPassive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getDurable() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getAutoDelete() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final boolean getInternal() - { - return (((int)(_bitfield0)) & ( 1 << 3)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 4)) != 0; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _exchange ); - size += getSizeOf( _type ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _type ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchExchangeDeclare(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeDeclareBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "type=" ); - buf.append( getType() ); - buf.append( ", " ); - buf.append( "passive=" ); - buf.append( getPassive() ); - buf.append( ", " ); - buf.append( "durable=" ); - buf.append( getDurable() ); - buf.append( ", " ); - buf.append( "autoDelete=" ); - buf.append( getAutoDelete() ); - buf.append( ", " ); - buf.append( "internal=" ); - buf.append( getInternal() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeDeclareOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeDeclareOkBodyImpl.java deleted file mode 100644 index 8d8ca793b8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeDeclareOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeDeclareOkBodyImpl extends AMQMethodBody_8_0 implements ExchangeDeclareOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeDeclareOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public ExchangeDeclareOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ExchangeDeclareOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchExchangeDeclareOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeDeclareOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeDeleteBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeDeleteBodyImpl.java deleted file mode 100644 index 2bfc0f13f4..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeDeleteBodyImpl.java +++ /dev/null @@ -1,154 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeDeleteBodyImpl extends AMQMethodBody_8_0 implements ExchangeDeleteBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeDeleteBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _exchange; // [exchange] - private final byte _bitfield0; // [ifUnused, nowait] - - // Constructor - public ExchangeDeleteBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _exchange = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public ExchangeDeleteBodyImpl( - int ticket, - AMQShortString exchange, - boolean ifUnused, - boolean nowait - ) - { - _ticket = ticket; - _exchange = exchange; - byte bitfield0 = (byte)0; - if( ifUnused ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final boolean getIfUnused() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _exchange ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _exchange ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchExchangeDelete(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeDeleteBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "ifUnused=" ); - buf.append( getIfUnused() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeDeleteOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeDeleteOkBodyImpl.java deleted file mode 100644 index 996072088c..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ExchangeDeleteOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class ExchangeDeleteOkBodyImpl extends AMQMethodBody_8_0 implements ExchangeDeleteOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new ExchangeDeleteOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 40; - public static final int METHOD_ID = 21; - - // Fields declared in specification - - // Constructor - public ExchangeDeleteOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public ExchangeDeleteOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchExchangeDeleteOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[ExchangeDeleteOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileAckBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileAckBodyImpl.java deleted file mode 100644 index 1efad0825a..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileAckBodyImpl.java +++ /dev/null @@ -1,128 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileAckBodyImpl extends AMQMethodBody_8_0 implements FileAckBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileAckBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 90; - - // Fields declared in specification - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [multiple] - - // Constructor - public FileAckBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public FileAckBodyImpl( - long deliveryTag, - boolean multiple - ) - { - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( multiple ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getMultiple() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 9; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFileAck(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileAckBodyImpl: "); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "multiple=" ); - buf.append( getMultiple() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileCancelBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileCancelBodyImpl.java deleted file mode 100644 index 422f6d8f16..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileCancelBodyImpl.java +++ /dev/null @@ -1,129 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileCancelBodyImpl extends AMQMethodBody_8_0 implements FileCancelBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileCancelBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [nowait] - - // Constructor - public FileCancelBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public FileCancelBodyImpl( - AMQShortString consumerTag, - boolean nowait - ) - { - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFileCancel(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileCancelBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileCancelOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileCancelOkBodyImpl.java deleted file mode 100644 index b100ce9f1b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileCancelOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileCancelOkBodyImpl extends AMQMethodBody_8_0 implements FileCancelOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileCancelOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public FileCancelOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public FileCancelOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFileCancelOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileCancelOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileConsumeBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileConsumeBodyImpl.java deleted file mode 100644 index 0a6aa06da4..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileConsumeBodyImpl.java +++ /dev/null @@ -1,193 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileConsumeBodyImpl extends AMQMethodBody_8_0 implements FileConsumeBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileConsumeBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [noLocal, noAck, exclusive, nowait] - - // Constructor - public FileConsumeBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public FileConsumeBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString consumerTag, - boolean noLocal, - boolean noAck, - boolean exclusive, - boolean nowait - ) - { - _ticket = ticket; - _queue = queue; - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( noLocal ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( noAck ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( exclusive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNoLocal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getNoAck() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getExclusive() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 3)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFileConsume(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileConsumeBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "noLocal=" ); - buf.append( getNoLocal() ); - buf.append( ", " ); - buf.append( "noAck=" ); - buf.append( getNoAck() ); - buf.append( ", " ); - buf.append( "exclusive=" ); - buf.append( getExclusive() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileConsumeOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileConsumeOkBodyImpl.java deleted file mode 100644 index cde5176f42..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileConsumeOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileConsumeOkBodyImpl extends AMQMethodBody_8_0 implements FileConsumeOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileConsumeOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public FileConsumeOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public FileConsumeOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFileConsumeOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileConsumeOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileDeliverBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileDeliverBodyImpl.java deleted file mode 100644 index 3cfd508dd7..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileDeliverBodyImpl.java +++ /dev/null @@ -1,181 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileDeliverBodyImpl extends AMQMethodBody_8_0 implements FileDeliverBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileDeliverBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 80; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [redelivered] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final AMQShortString _identifier; // [identifier] - - // Constructor - public FileDeliverBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _identifier = readAMQShortString( buffer ); - } - - public FileDeliverBodyImpl( - AMQShortString consumerTag, - long deliveryTag, - boolean redelivered, - AMQShortString exchange, - AMQShortString routingKey, - AMQShortString identifier - ) - { - _consumerTag = consumerTag; - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( redelivered ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - _bitfield0 = bitfield0; - _exchange = exchange; - _routingKey = routingKey; - _identifier = identifier; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getRedelivered() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final AMQShortString getIdentifier() - { - return _identifier; - } - - protected int getBodySize() - { - int size = 9; - size += getSizeOf( _consumerTag ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - size += getSizeOf( _identifier ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeAMQShortString( buffer, _identifier ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFileDeliver(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileDeliverBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "redelivered=" ); - buf.append( getRedelivered() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "identifier=" ); - buf.append( getIdentifier() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileOpenBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileOpenBodyImpl.java deleted file mode 100644 index aa79d22961..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileOpenBodyImpl.java +++ /dev/null @@ -1,124 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileOpenBodyImpl extends AMQMethodBody_8_0 implements FileOpenBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileOpenBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final AMQShortString _identifier; // [identifier] - private final long _contentSize; // [contentSize] - - // Constructor - public FileOpenBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _identifier = readAMQShortString( buffer ); - _contentSize = readLong( buffer ); - } - - public FileOpenBodyImpl( - AMQShortString identifier, - long contentSize - ) - { - _identifier = identifier; - _contentSize = contentSize; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getIdentifier() - { - return _identifier; - } - public final long getContentSize() - { - return _contentSize; - } - - protected int getBodySize() - { - int size = 8; - size += getSizeOf( _identifier ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _identifier ); - writeLong( buffer, _contentSize ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFileOpen(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileOpenBodyImpl: "); - buf.append( "identifier=" ); - buf.append( getIdentifier() ); - buf.append( ", " ); - buf.append( "contentSize=" ); - buf.append( getContentSize() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileOpenOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileOpenOkBodyImpl.java deleted file mode 100644 index 48845f7074..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileOpenOkBodyImpl.java +++ /dev/null @@ -1,111 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileOpenOkBodyImpl extends AMQMethodBody_8_0 implements FileOpenOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileOpenOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 41; - - // Fields declared in specification - private final long _stagedSize; // [stagedSize] - - // Constructor - public FileOpenOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _stagedSize = readLong( buffer ); - } - - public FileOpenOkBodyImpl( - long stagedSize - ) - { - _stagedSize = stagedSize; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getStagedSize() - { - return _stagedSize; - } - - protected int getBodySize() - { - int size = 8; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _stagedSize ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFileOpenOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileOpenOkBodyImpl: "); - buf.append( "stagedSize=" ); - buf.append( getStagedSize() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FilePublishBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FilePublishBodyImpl.java deleted file mode 100644 index c3e01ec686..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FilePublishBodyImpl.java +++ /dev/null @@ -1,181 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FilePublishBodyImpl extends AMQMethodBody_8_0 implements FilePublishBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FilePublishBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 60; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final byte _bitfield0; // [mandatory, immediate] - private final AMQShortString _identifier; // [identifier] - - // Constructor - public FilePublishBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _identifier = readAMQShortString( buffer ); - } - - public FilePublishBodyImpl( - int ticket, - AMQShortString exchange, - AMQShortString routingKey, - boolean mandatory, - boolean immediate, - AMQShortString identifier - ) - { - _ticket = ticket; - _exchange = exchange; - _routingKey = routingKey; - byte bitfield0 = (byte)0; - if( mandatory ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( immediate ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - _bitfield0 = bitfield0; - _identifier = identifier; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final boolean getMandatory() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getImmediate() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final AMQShortString getIdentifier() - { - return _identifier; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - size += getSizeOf( _identifier ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeBitfield( buffer, _bitfield0 ); - writeAMQShortString( buffer, _identifier ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFilePublish(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FilePublishBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "mandatory=" ); - buf.append( getMandatory() ); - buf.append( ", " ); - buf.append( "immediate=" ); - buf.append( getImmediate() ); - buf.append( ", " ); - buf.append( "identifier=" ); - buf.append( getIdentifier() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileQosBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileQosBodyImpl.java deleted file mode 100644 index f78156d8df..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileQosBodyImpl.java +++ /dev/null @@ -1,140 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileQosBodyImpl extends AMQMethodBody_8_0 implements FileQosBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileQosBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final long _prefetchSize; // [prefetchSize] - private final int _prefetchCount; // [prefetchCount] - private final byte _bitfield0; // [global] - - // Constructor - public FileQosBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _prefetchSize = readUnsignedInteger( buffer ); - _prefetchCount = readUnsignedShort( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public FileQosBodyImpl( - long prefetchSize, - int prefetchCount, - boolean global - ) - { - _prefetchSize = prefetchSize; - _prefetchCount = prefetchCount; - byte bitfield0 = (byte)0; - if( global ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getPrefetchSize() - { - return _prefetchSize; - } - public final int getPrefetchCount() - { - return _prefetchCount; - } - public final boolean getGlobal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 7; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _prefetchSize ); - writeUnsignedShort( buffer, _prefetchCount ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFileQos(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileQosBodyImpl: "); - buf.append( "prefetchSize=" ); - buf.append( getPrefetchSize() ); - buf.append( ", " ); - buf.append( "prefetchCount=" ); - buf.append( getPrefetchCount() ); - buf.append( ", " ); - buf.append( "global=" ); - buf.append( getGlobal() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileQosOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileQosOkBodyImpl.java deleted file mode 100644 index 17076f49b3..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileQosOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileQosOkBodyImpl extends AMQMethodBody_8_0 implements FileQosOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileQosOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public FileQosOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public FileQosOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFileQosOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileQosOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileRejectBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileRejectBodyImpl.java deleted file mode 100644 index a4e7a57540..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileRejectBodyImpl.java +++ /dev/null @@ -1,128 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileRejectBodyImpl extends AMQMethodBody_8_0 implements FileRejectBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileRejectBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 100; - - // Fields declared in specification - private final long _deliveryTag; // [deliveryTag] - private final byte _bitfield0; // [requeue] - - // Constructor - public FileRejectBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _deliveryTag = readLong( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public FileRejectBodyImpl( - long deliveryTag, - boolean requeue - ) - { - _deliveryTag = deliveryTag; - byte bitfield0 = (byte)0; - if( requeue ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final boolean getRequeue() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 9; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _deliveryTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFileReject(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileRejectBodyImpl: "); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "requeue=" ); - buf.append( getRequeue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileReturnBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileReturnBodyImpl.java deleted file mode 100644 index bf696ca668..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileReturnBodyImpl.java +++ /dev/null @@ -1,150 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileReturnBodyImpl extends AMQMethodBody_8_0 implements FileReturnBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileReturnBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 70; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - - // Constructor - public FileReturnBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - } - - public FileReturnBodyImpl( - int replyCode, - AMQShortString replyText, - AMQShortString exchange, - AMQShortString routingKey - ) - { - _replyCode = replyCode; - _replyText = replyText; - _exchange = exchange; - _routingKey = routingKey; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _replyText ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFileReturn(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileReturnBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileStageBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileStageBodyImpl.java deleted file mode 100644 index 8e2185801b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/FileStageBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class FileStageBodyImpl extends AMQMethodBody_8_0 implements FileStageBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new FileStageBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 70; - public static final int METHOD_ID = 50; - - // Fields declared in specification - - // Constructor - public FileStageBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public FileStageBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchFileStage(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[FileStageBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/MethodConverter_8_0.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/MethodConverter_8_0.java deleted file mode 100644 index 5e50c2b3fb..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/MethodConverter_8_0.java +++ /dev/null @@ -1,64 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.framing.AMQMethodBody; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.BasicPublishBody; -import org.apache.qpid.framing.abstraction.AbstractMethodConverter; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; -import org.apache.qpid.framing.abstraction.MessagePublishInfoImpl; -import org.apache.qpid.framing.abstraction.ProtocolVersionMethodConverter; - -public class MethodConverter_8_0 extends AbstractMethodConverter implements ProtocolVersionMethodConverter -{ - public MethodConverter_8_0() - { - super((byte)8,(byte)0); - } - - - public MessagePublishInfo convertToInfo(AMQMethodBody methodBody) - { - final BasicPublishBody publishBody = ((BasicPublishBody) methodBody); - - final AMQShortString exchange = publishBody.getExchange(); - final AMQShortString routingKey = publishBody.getRoutingKey(); - - return new MessagePublishInfoImpl(exchange == null ? null : exchange.intern(), - publishBody.getImmediate(), - publishBody.getMandatory(), - routingKey == null ? null : routingKey.intern(false)); - - } - - public AMQMethodBody convertToBody(MessagePublishInfo info) - { - - return new BasicPublishBodyImpl(0, - info.getExchange(), - info.getRoutingKey(), - info.isMandatory(), - info.isImmediate()) ; - - } -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/MethodDispatcher_8_0.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/MethodDispatcher_8_0.java deleted file mode 100644 index dc4f33ab6d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/MethodDispatcher_8_0.java +++ /dev/null @@ -1,38 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.framing.*; - -public interface MethodDispatcher_8_0 - extends MethodDispatcher, - ServerMethodDispatcher_8_0, - ClientMethodDispatcher_8_0 -{ - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/MethodRegistry_8_0.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/MethodRegistry_8_0.java deleted file mode 100644 index f3c1888e2a..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/MethodRegistry_8_0.java +++ /dev/null @@ -1,1407 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.framing.*; -import org.apache.qpid.protocol.AMQConstant; - - -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import java.io.IOException; - -import org.apache.qpid.framing.abstraction.ProtocolVersionMethodConverter; -import org.apache.qpid.codec.MarkableDataInput; - - -public class MethodRegistry_8_0 extends MethodRegistry -{ - - private static final Logger _log = LoggerFactory.getLogger(MethodRegistry.class); - - private ProtocolVersionMethodConverter _protocolVersionConverter = new MethodConverter_8_0(); - - private final AMQMethodBodyInstanceFactory[][] _factories = new AMQMethodBodyInstanceFactory[121][]; - - public MethodRegistry_8_0() - { - this(new ProtocolVersion((byte)8,(byte)0)); - } - - public MethodRegistry_8_0(ProtocolVersion pv) - { - super(pv); - - - - // Register method body instance factories for the Connection class. - - _factories[10] = new AMQMethodBodyInstanceFactory[62]; - - _factories[10][10] = ConnectionStartBodyImpl.getFactory(); - _factories[10][11] = ConnectionStartOkBodyImpl.getFactory(); - _factories[10][20] = ConnectionSecureBodyImpl.getFactory(); - _factories[10][21] = ConnectionSecureOkBodyImpl.getFactory(); - _factories[10][30] = ConnectionTuneBodyImpl.getFactory(); - _factories[10][31] = ConnectionTuneOkBodyImpl.getFactory(); - _factories[10][40] = ConnectionOpenBodyImpl.getFactory(); - _factories[10][41] = ConnectionOpenOkBodyImpl.getFactory(); - _factories[10][50] = ConnectionRedirectBodyImpl.getFactory(); - _factories[10][60] = ConnectionCloseBodyImpl.getFactory(); - _factories[10][61] = ConnectionCloseOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Channel class. - - _factories[20] = new AMQMethodBodyInstanceFactory[42]; - - _factories[20][10] = ChannelOpenBodyImpl.getFactory(); - _factories[20][11] = ChannelOpenOkBodyImpl.getFactory(); - _factories[20][20] = ChannelFlowBodyImpl.getFactory(); - _factories[20][21] = ChannelFlowOkBodyImpl.getFactory(); - _factories[20][30] = ChannelAlertBodyImpl.getFactory(); - _factories[20][40] = ChannelCloseBodyImpl.getFactory(); - _factories[20][41] = ChannelCloseOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Access class. - - _factories[30] = new AMQMethodBodyInstanceFactory[12]; - - _factories[30][10] = AccessRequestBodyImpl.getFactory(); - _factories[30][11] = AccessRequestOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Exchange class. - - _factories[40] = new AMQMethodBodyInstanceFactory[24]; - - _factories[40][10] = ExchangeDeclareBodyImpl.getFactory(); - _factories[40][11] = ExchangeDeclareOkBodyImpl.getFactory(); - _factories[40][20] = ExchangeDeleteBodyImpl.getFactory(); - _factories[40][21] = ExchangeDeleteOkBodyImpl.getFactory(); - _factories[40][22] = ExchangeBoundBodyImpl.getFactory(); - _factories[40][23] = ExchangeBoundOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Queue class. - - _factories[50] = new AMQMethodBodyInstanceFactory[42]; - - _factories[50][10] = QueueDeclareBodyImpl.getFactory(); - _factories[50][11] = QueueDeclareOkBodyImpl.getFactory(); - _factories[50][20] = QueueBindBodyImpl.getFactory(); - _factories[50][21] = QueueBindOkBodyImpl.getFactory(); - _factories[50][30] = QueuePurgeBodyImpl.getFactory(); - _factories[50][31] = QueuePurgeOkBodyImpl.getFactory(); - _factories[50][40] = QueueDeleteBodyImpl.getFactory(); - _factories[50][41] = QueueDeleteOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Basic class. - - _factories[60] = new AMQMethodBodyInstanceFactory[102]; - - _factories[60][10] = BasicQosBodyImpl.getFactory(); - _factories[60][11] = BasicQosOkBodyImpl.getFactory(); - _factories[60][20] = BasicConsumeBodyImpl.getFactory(); - _factories[60][21] = BasicConsumeOkBodyImpl.getFactory(); - _factories[60][30] = BasicCancelBodyImpl.getFactory(); - _factories[60][31] = BasicCancelOkBodyImpl.getFactory(); - _factories[60][40] = BasicPublishBodyImpl.getFactory(); - _factories[60][50] = BasicReturnBodyImpl.getFactory(); - _factories[60][60] = BasicDeliverBodyImpl.getFactory(); - _factories[60][70] = BasicGetBodyImpl.getFactory(); - _factories[60][71] = BasicGetOkBodyImpl.getFactory(); - _factories[60][72] = BasicGetEmptyBodyImpl.getFactory(); - _factories[60][80] = BasicAckBodyImpl.getFactory(); - _factories[60][90] = BasicRejectBodyImpl.getFactory(); - _factories[60][100] = BasicRecoverBodyImpl.getFactory(); - _factories[60][101] = BasicRecoverOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the File class. - - _factories[70] = new AMQMethodBodyInstanceFactory[101]; - - _factories[70][10] = FileQosBodyImpl.getFactory(); - _factories[70][11] = FileQosOkBodyImpl.getFactory(); - _factories[70][20] = FileConsumeBodyImpl.getFactory(); - _factories[70][21] = FileConsumeOkBodyImpl.getFactory(); - _factories[70][30] = FileCancelBodyImpl.getFactory(); - _factories[70][31] = FileCancelOkBodyImpl.getFactory(); - _factories[70][40] = FileOpenBodyImpl.getFactory(); - _factories[70][41] = FileOpenOkBodyImpl.getFactory(); - _factories[70][50] = FileStageBodyImpl.getFactory(); - _factories[70][60] = FilePublishBodyImpl.getFactory(); - _factories[70][70] = FileReturnBodyImpl.getFactory(); - _factories[70][80] = FileDeliverBodyImpl.getFactory(); - _factories[70][90] = FileAckBodyImpl.getFactory(); - _factories[70][100] = FileRejectBodyImpl.getFactory(); - - - - // Register method body instance factories for the Stream class. - - _factories[80] = new AMQMethodBodyInstanceFactory[61]; - - _factories[80][10] = StreamQosBodyImpl.getFactory(); - _factories[80][11] = StreamQosOkBodyImpl.getFactory(); - _factories[80][20] = StreamConsumeBodyImpl.getFactory(); - _factories[80][21] = StreamConsumeOkBodyImpl.getFactory(); - _factories[80][30] = StreamCancelBodyImpl.getFactory(); - _factories[80][31] = StreamCancelOkBodyImpl.getFactory(); - _factories[80][40] = StreamPublishBodyImpl.getFactory(); - _factories[80][50] = StreamReturnBodyImpl.getFactory(); - _factories[80][60] = StreamDeliverBodyImpl.getFactory(); - - - - // Register method body instance factories for the Tx class. - - _factories[90] = new AMQMethodBodyInstanceFactory[32]; - - _factories[90][10] = TxSelectBodyImpl.getFactory(); - _factories[90][11] = TxSelectOkBodyImpl.getFactory(); - _factories[90][20] = TxCommitBodyImpl.getFactory(); - _factories[90][21] = TxCommitOkBodyImpl.getFactory(); - _factories[90][30] = TxRollbackBodyImpl.getFactory(); - _factories[90][31] = TxRollbackOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Dtx class. - - _factories[100] = new AMQMethodBodyInstanceFactory[22]; - - _factories[100][10] = DtxSelectBodyImpl.getFactory(); - _factories[100][11] = DtxSelectOkBodyImpl.getFactory(); - _factories[100][20] = DtxStartBodyImpl.getFactory(); - _factories[100][21] = DtxStartOkBodyImpl.getFactory(); - - - - // Register method body instance factories for the Tunnel class. - - _factories[110] = new AMQMethodBodyInstanceFactory[11]; - - _factories[110][10] = TunnelRequestBodyImpl.getFactory(); - - - - // Register method body instance factories for the Test class. - - _factories[120] = new AMQMethodBodyInstanceFactory[42]; - - _factories[120][10] = TestIntegerBodyImpl.getFactory(); - _factories[120][11] = TestIntegerOkBodyImpl.getFactory(); - _factories[120][20] = TestStringBodyImpl.getFactory(); - _factories[120][21] = TestStringOkBodyImpl.getFactory(); - _factories[120][30] = TestTableBodyImpl.getFactory(); - _factories[120][31] = TestTableOkBodyImpl.getFactory(); - _factories[120][40] = TestContentBodyImpl.getFactory(); - _factories[120][41] = TestContentOkBodyImpl.getFactory(); - } - - public AMQMethodBody convertToBody(MarkableDataInput in, long size) - throws AMQFrameDecodingException, IOException - { - int classId = in.readUnsignedShort(); - int methodId = in.readUnsignedShort(); - - AMQMethodBodyInstanceFactory bodyFactory; - try - { - bodyFactory = _factories[classId][methodId]; - } - catch(NullPointerException e) - { - throw new AMQFrameDecodingException(AMQConstant.COMMAND_INVALID, - "Class " + classId + " unknown in AMQP version 8-0" - + " (while trying to decode class " + classId + " method " + methodId + "."); - } - catch(IndexOutOfBoundsException e) - { - if(classId >= _factories.length) - { - throw new AMQFrameDecodingException(AMQConstant.COMMAND_INVALID, - "Class " + classId + " unknown in AMQP version 8-0" - + " (while trying to decode class " + classId + " method " + methodId + "."); - - } - else - { - throw new AMQFrameDecodingException(AMQConstant.COMMAND_INVALID, - "Method " + methodId + " unknown in AMQP version 8-0" - + " (while trying to decode class " + classId + " method " + methodId + "."); - - } - } - - if (bodyFactory == null) - { - throw new AMQFrameDecodingException(AMQConstant.COMMAND_INVALID, - "Method " + methodId + " unknown in AMQP version 8-0" - + " (while trying to decode class " + classId + " method " + methodId + "."); - } - - return bodyFactory.newInstance(in, size); - } - - public int getMaxClassId() - { - return 120; - } - - public int getMaxMethodId(int classId) - { - return _factories[classId].length - 1; - } - - - - public ConnectionStartBody createConnectionStartBody( - final short versionMajor, - final short versionMinor, - final FieldTable serverProperties, - final byte[] mechanisms, - final byte[] locales - ) - { - return new ConnectionStartBodyImpl( - versionMajor, - versionMinor, - serverProperties, - mechanisms, - locales - ); - } - - public ConnectionStartOkBody createConnectionStartOkBody( - final FieldTable clientProperties, - final AMQShortString mechanism, - final byte[] response, - final AMQShortString locale - ) - { - return new ConnectionStartOkBodyImpl( - clientProperties, - mechanism, - response, - locale - ); - } - - public ConnectionSecureBody createConnectionSecureBody( - final byte[] challenge - ) - { - return new ConnectionSecureBodyImpl( - challenge - ); - } - - public ConnectionSecureOkBody createConnectionSecureOkBody( - final byte[] response - ) - { - return new ConnectionSecureOkBodyImpl( - response - ); - } - - public ConnectionTuneBody createConnectionTuneBody( - final int channelMax, - final long frameMax, - final int heartbeat - ) - { - return new ConnectionTuneBodyImpl( - channelMax, - frameMax, - heartbeat - ); - } - - public ConnectionTuneOkBody createConnectionTuneOkBody( - final int channelMax, - final long frameMax, - final int heartbeat - ) - { - return new ConnectionTuneOkBodyImpl( - channelMax, - frameMax, - heartbeat - ); - } - - public ConnectionOpenBody createConnectionOpenBody( - final AMQShortString virtualHost, - final AMQShortString capabilities, - final boolean insist - ) - { - return new ConnectionOpenBodyImpl( - virtualHost, - capabilities, - insist - ); - } - - public ConnectionOpenOkBody createConnectionOpenOkBody( - final AMQShortString knownHosts - ) - { - return new ConnectionOpenOkBodyImpl( - knownHosts - ); - } - - public ConnectionRedirectBody createConnectionRedirectBody( - final AMQShortString host, - final AMQShortString knownHosts - ) - { - return new ConnectionRedirectBodyImpl( - host, - knownHosts - ); - } - - public ConnectionCloseBody createConnectionCloseBody( - final int replyCode, - final AMQShortString replyText, - final int classId, - final int methodId - ) - { - return new ConnectionCloseBodyImpl( - replyCode, - replyText, - classId, - methodId - ); - } - - public ConnectionCloseOkBody createConnectionCloseOkBody( - ) - { - return new ConnectionCloseOkBodyImpl( - ); - } - - - - - public ChannelOpenBody createChannelOpenBody( - final AMQShortString outOfBand - ) - { - return new ChannelOpenBodyImpl( - outOfBand - ); - } - - public ChannelOpenOkBody createChannelOpenOkBody( - ) - { - return new ChannelOpenOkBodyImpl( - ); - } - - public ChannelFlowBody createChannelFlowBody( - final boolean active - ) - { - return new ChannelFlowBodyImpl( - active - ); - } - - public ChannelFlowOkBody createChannelFlowOkBody( - final boolean active - ) - { - return new ChannelFlowOkBodyImpl( - active - ); - } - - public ChannelAlertBody createChannelAlertBody( - final int replyCode, - final AMQShortString replyText, - final FieldTable details - ) - { - return new ChannelAlertBodyImpl( - replyCode, - replyText, - details - ); - } - - public ChannelCloseBody createChannelCloseBody( - final int replyCode, - final AMQShortString replyText, - final int classId, - final int methodId - ) - { - return new ChannelCloseBodyImpl( - replyCode, - replyText, - classId, - methodId - ); - } - - public ChannelCloseOkBody createChannelCloseOkBody( - ) - { - return new ChannelCloseOkBodyImpl( - ); - } - - - - - public AccessRequestBody createAccessRequestBody( - final AMQShortString realm, - final boolean exclusive, - final boolean passive, - final boolean active, - final boolean write, - final boolean read - ) - { - return new AccessRequestBodyImpl( - realm, - exclusive, - passive, - active, - write, - read - ); - } - - public AccessRequestOkBody createAccessRequestOkBody( - final int ticket - ) - { - return new AccessRequestOkBodyImpl( - ticket - ); - } - - - - - public ExchangeDeclareBody createExchangeDeclareBody( - final int ticket, - final AMQShortString exchange, - final AMQShortString type, - final boolean passive, - final boolean durable, - final boolean autoDelete, - final boolean internal, - final boolean nowait, - final FieldTable arguments - ) - { - return new ExchangeDeclareBodyImpl( - ticket, - exchange, - type, - passive, - durable, - autoDelete, - internal, - nowait, - arguments - ); - } - - public ExchangeDeclareOkBody createExchangeDeclareOkBody( - ) - { - return new ExchangeDeclareOkBodyImpl( - ); - } - - public ExchangeDeleteBody createExchangeDeleteBody( - final int ticket, - final AMQShortString exchange, - final boolean ifUnused, - final boolean nowait - ) - { - return new ExchangeDeleteBodyImpl( - ticket, - exchange, - ifUnused, - nowait - ); - } - - public ExchangeDeleteOkBody createExchangeDeleteOkBody( - ) - { - return new ExchangeDeleteOkBodyImpl( - ); - } - - public ExchangeBoundBody createExchangeBoundBody( - final AMQShortString exchange, - final AMQShortString routingKey, - final AMQShortString queue - ) - { - return new ExchangeBoundBodyImpl( - exchange, - routingKey, - queue - ); - } - - public ExchangeBoundOkBody createExchangeBoundOkBody( - final int replyCode, - final AMQShortString replyText - ) - { - return new ExchangeBoundOkBodyImpl( - replyCode, - replyText - ); - } - - - - - public QueueDeclareBody createQueueDeclareBody( - final int ticket, - final AMQShortString queue, - final boolean passive, - final boolean durable, - final boolean exclusive, - final boolean autoDelete, - final boolean nowait, - final FieldTable arguments - ) - { - return new QueueDeclareBodyImpl( - ticket, - queue, - passive, - durable, - exclusive, - autoDelete, - nowait, - arguments - ); - } - - public QueueDeclareOkBody createQueueDeclareOkBody( - final AMQShortString queue, - final long messageCount, - final long consumerCount - ) - { - return new QueueDeclareOkBodyImpl( - queue, - messageCount, - consumerCount - ); - } - - public QueueBindBody createQueueBindBody( - final int ticket, - final AMQShortString queue, - final AMQShortString exchange, - final AMQShortString routingKey, - final boolean nowait, - final FieldTable arguments - ) - { - return new QueueBindBodyImpl( - ticket, - queue, - exchange, - routingKey, - nowait, - arguments - ); - } - - public QueueBindOkBody createQueueBindOkBody( - ) - { - return new QueueBindOkBodyImpl( - ); - } - - public QueuePurgeBody createQueuePurgeBody( - final int ticket, - final AMQShortString queue, - final boolean nowait - ) - { - return new QueuePurgeBodyImpl( - ticket, - queue, - nowait - ); - } - - public QueuePurgeOkBody createQueuePurgeOkBody( - final long messageCount - ) - { - return new QueuePurgeOkBodyImpl( - messageCount - ); - } - - public QueueDeleteBody createQueueDeleteBody( - final int ticket, - final AMQShortString queue, - final boolean ifUnused, - final boolean ifEmpty, - final boolean nowait - ) - { - return new QueueDeleteBodyImpl( - ticket, - queue, - ifUnused, - ifEmpty, - nowait - ); - } - - public QueueDeleteOkBody createQueueDeleteOkBody( - final long messageCount - ) - { - return new QueueDeleteOkBodyImpl( - messageCount - ); - } - - - - - public BasicQosBody createBasicQosBody( - final long prefetchSize, - final int prefetchCount, - final boolean global - ) - { - return new BasicQosBodyImpl( - prefetchSize, - prefetchCount, - global - ); - } - - public BasicQosOkBody createBasicQosOkBody( - ) - { - return new BasicQosOkBodyImpl( - ); - } - - public BasicConsumeBody createBasicConsumeBody( - final int ticket, - final AMQShortString queue, - final AMQShortString consumerTag, - final boolean noLocal, - final boolean noAck, - final boolean exclusive, - final boolean nowait, - final FieldTable arguments - ) - { - return new BasicConsumeBodyImpl( - ticket, - queue, - consumerTag, - noLocal, - noAck, - exclusive, - nowait, - arguments - ); - } - - public BasicConsumeOkBody createBasicConsumeOkBody( - final AMQShortString consumerTag - ) - { - return new BasicConsumeOkBodyImpl( - consumerTag - ); - } - - public BasicCancelBody createBasicCancelBody( - final AMQShortString consumerTag, - final boolean nowait - ) - { - return new BasicCancelBodyImpl( - consumerTag, - nowait - ); - } - - public BasicCancelOkBody createBasicCancelOkBody( - final AMQShortString consumerTag - ) - { - return new BasicCancelOkBodyImpl( - consumerTag - ); - } - - public BasicPublishBody createBasicPublishBody( - final int ticket, - final AMQShortString exchange, - final AMQShortString routingKey, - final boolean mandatory, - final boolean immediate - ) - { - return new BasicPublishBodyImpl( - ticket, - exchange, - routingKey, - mandatory, - immediate - ); - } - - public BasicReturnBody createBasicReturnBody( - final int replyCode, - final AMQShortString replyText, - final AMQShortString exchange, - final AMQShortString routingKey - ) - { - return new BasicReturnBodyImpl( - replyCode, - replyText, - exchange, - routingKey - ); - } - - public BasicDeliverBody createBasicDeliverBody( - final AMQShortString consumerTag, - final long deliveryTag, - final boolean redelivered, - final AMQShortString exchange, - final AMQShortString routingKey - ) - { - return new BasicDeliverBodyImpl( - consumerTag, - deliveryTag, - redelivered, - exchange, - routingKey - ); - } - - public BasicGetBody createBasicGetBody( - final int ticket, - final AMQShortString queue, - final boolean noAck - ) - { - return new BasicGetBodyImpl( - ticket, - queue, - noAck - ); - } - - public BasicGetOkBody createBasicGetOkBody( - final long deliveryTag, - final boolean redelivered, - final AMQShortString exchange, - final AMQShortString routingKey, - final long messageCount - ) - { - return new BasicGetOkBodyImpl( - deliveryTag, - redelivered, - exchange, - routingKey, - messageCount - ); - } - - public BasicGetEmptyBody createBasicGetEmptyBody( - final AMQShortString clusterId - ) - { - return new BasicGetEmptyBodyImpl( - clusterId - ); - } - - public BasicAckBody createBasicAckBody( - final long deliveryTag, - final boolean multiple - ) - { - return new BasicAckBodyImpl( - deliveryTag, - multiple - ); - } - - public BasicRejectBody createBasicRejectBody( - final long deliveryTag, - final boolean requeue - ) - { - return new BasicRejectBodyImpl( - deliveryTag, - requeue - ); - } - - public BasicRecoverBody createBasicRecoverBody( - final boolean requeue - ) - { - return new BasicRecoverBodyImpl( - requeue - ); - } - - public BasicRecoverOkBody createBasicRecoverOkBody( - ) - { - return new BasicRecoverOkBodyImpl( - ); - } - - - - - public FileQosBody createFileQosBody( - final long prefetchSize, - final int prefetchCount, - final boolean global - ) - { - return new FileQosBodyImpl( - prefetchSize, - prefetchCount, - global - ); - } - - public FileQosOkBody createFileQosOkBody( - ) - { - return new FileQosOkBodyImpl( - ); - } - - public FileConsumeBody createFileConsumeBody( - final int ticket, - final AMQShortString queue, - final AMQShortString consumerTag, - final boolean noLocal, - final boolean noAck, - final boolean exclusive, - final boolean nowait - ) - { - return new FileConsumeBodyImpl( - ticket, - queue, - consumerTag, - noLocal, - noAck, - exclusive, - nowait - ); - } - - public FileConsumeOkBody createFileConsumeOkBody( - final AMQShortString consumerTag - ) - { - return new FileConsumeOkBodyImpl( - consumerTag - ); - } - - public FileCancelBody createFileCancelBody( - final AMQShortString consumerTag, - final boolean nowait - ) - { - return new FileCancelBodyImpl( - consumerTag, - nowait - ); - } - - public FileCancelOkBody createFileCancelOkBody( - final AMQShortString consumerTag - ) - { - return new FileCancelOkBodyImpl( - consumerTag - ); - } - - public FileOpenBody createFileOpenBody( - final AMQShortString identifier, - final long contentSize - ) - { - return new FileOpenBodyImpl( - identifier, - contentSize - ); - } - - public FileOpenOkBody createFileOpenOkBody( - final long stagedSize - ) - { - return new FileOpenOkBodyImpl( - stagedSize - ); - } - - public FileStageBody createFileStageBody( - ) - { - return new FileStageBodyImpl( - ); - } - - public FilePublishBody createFilePublishBody( - final int ticket, - final AMQShortString exchange, - final AMQShortString routingKey, - final boolean mandatory, - final boolean immediate, - final AMQShortString identifier - ) - { - return new FilePublishBodyImpl( - ticket, - exchange, - routingKey, - mandatory, - immediate, - identifier - ); - } - - public FileReturnBody createFileReturnBody( - final int replyCode, - final AMQShortString replyText, - final AMQShortString exchange, - final AMQShortString routingKey - ) - { - return new FileReturnBodyImpl( - replyCode, - replyText, - exchange, - routingKey - ); - } - - public FileDeliverBody createFileDeliverBody( - final AMQShortString consumerTag, - final long deliveryTag, - final boolean redelivered, - final AMQShortString exchange, - final AMQShortString routingKey, - final AMQShortString identifier - ) - { - return new FileDeliverBodyImpl( - consumerTag, - deliveryTag, - redelivered, - exchange, - routingKey, - identifier - ); - } - - public FileAckBody createFileAckBody( - final long deliveryTag, - final boolean multiple - ) - { - return new FileAckBodyImpl( - deliveryTag, - multiple - ); - } - - public FileRejectBody createFileRejectBody( - final long deliveryTag, - final boolean requeue - ) - { - return new FileRejectBodyImpl( - deliveryTag, - requeue - ); - } - - - - - public StreamQosBody createStreamQosBody( - final long prefetchSize, - final int prefetchCount, - final long consumeRate, - final boolean global - ) - { - return new StreamQosBodyImpl( - prefetchSize, - prefetchCount, - consumeRate, - global - ); - } - - public StreamQosOkBody createStreamQosOkBody( - ) - { - return new StreamQosOkBodyImpl( - ); - } - - public StreamConsumeBody createStreamConsumeBody( - final int ticket, - final AMQShortString queue, - final AMQShortString consumerTag, - final boolean noLocal, - final boolean exclusive, - final boolean nowait - ) - { - return new StreamConsumeBodyImpl( - ticket, - queue, - consumerTag, - noLocal, - exclusive, - nowait - ); - } - - public StreamConsumeOkBody createStreamConsumeOkBody( - final AMQShortString consumerTag - ) - { - return new StreamConsumeOkBodyImpl( - consumerTag - ); - } - - public StreamCancelBody createStreamCancelBody( - final AMQShortString consumerTag, - final boolean nowait - ) - { - return new StreamCancelBodyImpl( - consumerTag, - nowait - ); - } - - public StreamCancelOkBody createStreamCancelOkBody( - final AMQShortString consumerTag - ) - { - return new StreamCancelOkBodyImpl( - consumerTag - ); - } - - public StreamPublishBody createStreamPublishBody( - final int ticket, - final AMQShortString exchange, - final AMQShortString routingKey, - final boolean mandatory, - final boolean immediate - ) - { - return new StreamPublishBodyImpl( - ticket, - exchange, - routingKey, - mandatory, - immediate - ); - } - - public StreamReturnBody createStreamReturnBody( - final int replyCode, - final AMQShortString replyText, - final AMQShortString exchange, - final AMQShortString routingKey - ) - { - return new StreamReturnBodyImpl( - replyCode, - replyText, - exchange, - routingKey - ); - } - - public StreamDeliverBody createStreamDeliverBody( - final AMQShortString consumerTag, - final long deliveryTag, - final AMQShortString exchange, - final AMQShortString queue - ) - { - return new StreamDeliverBodyImpl( - consumerTag, - deliveryTag, - exchange, - queue - ); - } - - - - - public TxSelectBody createTxSelectBody( - ) - { - return new TxSelectBodyImpl( - ); - } - - public TxSelectOkBody createTxSelectOkBody( - ) - { - return new TxSelectOkBodyImpl( - ); - } - - public TxCommitBody createTxCommitBody( - ) - { - return new TxCommitBodyImpl( - ); - } - - public TxCommitOkBody createTxCommitOkBody( - ) - { - return new TxCommitOkBodyImpl( - ); - } - - public TxRollbackBody createTxRollbackBody( - ) - { - return new TxRollbackBodyImpl( - ); - } - - public TxRollbackOkBody createTxRollbackOkBody( - ) - { - return new TxRollbackOkBodyImpl( - ); - } - - - - - public DtxSelectBody createDtxSelectBody( - ) - { - return new DtxSelectBodyImpl( - ); - } - - public DtxSelectOkBody createDtxSelectOkBody( - ) - { - return new DtxSelectOkBodyImpl( - ); - } - - public DtxStartBody createDtxStartBody( - final AMQShortString dtxIdentifier - ) - { - return new DtxStartBodyImpl( - dtxIdentifier - ); - } - - public DtxStartOkBody createDtxStartOkBody( - ) - { - return new DtxStartOkBodyImpl( - ); - } - - - - - public TunnelRequestBody createTunnelRequestBody( - final FieldTable metaData - ) - { - return new TunnelRequestBodyImpl( - metaData - ); - } - - - - - public TestIntegerBody createTestIntegerBody( - final short integer1, - final int integer2, - final long integer3, - final long integer4, - final short operation - ) - { - return new TestIntegerBodyImpl( - integer1, - integer2, - integer3, - integer4, - operation - ); - } - - public TestIntegerOkBody createTestIntegerOkBody( - final long result - ) - { - return new TestIntegerOkBodyImpl( - result - ); - } - - public TestStringBody createTestStringBody( - final AMQShortString string1, - final byte[] string2, - final short operation - ) - { - return new TestStringBodyImpl( - string1, - string2, - operation - ); - } - - public TestStringOkBody createTestStringOkBody( - final byte[] result - ) - { - return new TestStringOkBodyImpl( - result - ); - } - - public TestTableBody createTestTableBody( - final FieldTable table, - final short integerOp, - final short stringOp - ) - { - return new TestTableBodyImpl( - table, - integerOp, - stringOp - ); - } - - public TestTableOkBody createTestTableOkBody( - final long integerResult, - final byte[] stringResult - ) - { - return new TestTableOkBodyImpl( - integerResult, - stringResult - ); - } - - public TestContentBody createTestContentBody( - ) - { - return new TestContentBodyImpl( - ); - } - - public TestContentOkBody createTestContentOkBody( - final long contentChecksum - ) - { - return new TestContentOkBodyImpl( - contentChecksum - ); - } - - - - public ProtocolVersionMethodConverter getProtocolVersionMethodConverter() - { - return _protocolVersionConverter; - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueBindBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueBindBodyImpl.java deleted file mode 100644 index b4acb6ae06..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueBindBodyImpl.java +++ /dev/null @@ -1,181 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueBindBodyImpl extends AMQMethodBody_8_0 implements QueueBindBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueBindBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final byte _bitfield0; // [nowait] - private final FieldTable _arguments; // [arguments] - - // Constructor - public QueueBindBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _arguments = readFieldTable( buffer ); - } - - public QueueBindBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString exchange, - AMQShortString routingKey, - boolean nowait, - FieldTable arguments - ) - { - _ticket = ticket; - _queue = queue; - _exchange = exchange; - _routingKey = routingKey; - byte bitfield0 = (byte)0; - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - _bitfield0 = bitfield0; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchQueueBind(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueBindBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueBindOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueBindOkBodyImpl.java deleted file mode 100644 index 6a0b78db2d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueBindOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueBindOkBodyImpl extends AMQMethodBody_8_0 implements QueueBindOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueBindOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 21; - - // Fields declared in specification - - // Constructor - public QueueBindOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public QueueBindOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchQueueBindOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueBindOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueDeclareBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueDeclareBodyImpl.java deleted file mode 100644 index 4e835bd12b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueDeclareBodyImpl.java +++ /dev/null @@ -1,207 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueDeclareBodyImpl extends AMQMethodBody_8_0 implements QueueDeclareBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueDeclareBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final byte _bitfield0; // [passive, durable, exclusive, autoDelete, nowait] - private final FieldTable _arguments; // [arguments] - - // Constructor - public QueueDeclareBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - _arguments = readFieldTable( buffer ); - } - - public QueueDeclareBodyImpl( - int ticket, - AMQShortString queue, - boolean passive, - boolean durable, - boolean exclusive, - boolean autoDelete, - boolean nowait, - FieldTable arguments - ) - { - _ticket = ticket; - _queue = queue; - byte bitfield0 = (byte)0; - if( passive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( durable ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( exclusive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - - if( autoDelete ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 3)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 4)); - } - - _bitfield0 = bitfield0; - _arguments = arguments; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final boolean getPassive() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getDurable() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getExclusive() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - public final boolean getAutoDelete() - { - return (((int)(_bitfield0)) & ( 1 << 3)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 4)) != 0; - } - public final FieldTable getArguments() - { - return _arguments; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _arguments ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeBitfield( buffer, _bitfield0 ); - writeFieldTable( buffer, _arguments ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchQueueDeclare(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueDeclareBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "passive=" ); - buf.append( getPassive() ); - buf.append( ", " ); - buf.append( "durable=" ); - buf.append( getDurable() ); - buf.append( ", " ); - buf.append( "exclusive=" ); - buf.append( getExclusive() ); - buf.append( ", " ); - buf.append( "autoDelete=" ); - buf.append( getAutoDelete() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append( ", " ); - buf.append( "arguments=" ); - buf.append( getArguments() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueDeclareOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueDeclareOkBodyImpl.java deleted file mode 100644 index 09abf5865e..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueDeclareOkBodyImpl.java +++ /dev/null @@ -1,136 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueDeclareOkBodyImpl extends AMQMethodBody_8_0 implements QueueDeclareOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueDeclareOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 11; - - // Fields declared in specification - private final AMQShortString _queue; // [queue] - private final long _messageCount; // [messageCount] - private final long _consumerCount; // [consumerCount] - - // Constructor - public QueueDeclareOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _queue = readAMQShortString( buffer ); - _messageCount = readUnsignedInteger( buffer ); - _consumerCount = readUnsignedInteger( buffer ); - } - - public QueueDeclareOkBodyImpl( - AMQShortString queue, - long messageCount, - long consumerCount - ) - { - _queue = queue; - _messageCount = messageCount; - _consumerCount = consumerCount; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getQueue() - { - return _queue; - } - public final long getMessageCount() - { - return _messageCount; - } - public final long getConsumerCount() - { - return _consumerCount; - } - - protected int getBodySize() - { - int size = 8; - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _queue ); - writeUnsignedInteger( buffer, _messageCount ); - writeUnsignedInteger( buffer, _consumerCount ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchQueueDeclareOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueDeclareOkBodyImpl: "); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "messageCount=" ); - buf.append( getMessageCount() ); - buf.append( ", " ); - buf.append( "consumerCount=" ); - buf.append( getConsumerCount() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueDeleteBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueDeleteBodyImpl.java deleted file mode 100644 index ada079c4c1..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueDeleteBodyImpl.java +++ /dev/null @@ -1,167 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueDeleteBodyImpl extends AMQMethodBody_8_0 implements QueueDeleteBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueDeleteBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final byte _bitfield0; // [ifUnused, ifEmpty, nowait] - - // Constructor - public QueueDeleteBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public QueueDeleteBodyImpl( - int ticket, - AMQShortString queue, - boolean ifUnused, - boolean ifEmpty, - boolean nowait - ) - { - _ticket = ticket; - _queue = queue; - byte bitfield0 = (byte)0; - if( ifUnused ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( ifEmpty ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final boolean getIfUnused() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getIfEmpty() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchQueueDelete(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueDeleteBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "ifUnused=" ); - buf.append( getIfUnused() ); - buf.append( ", " ); - buf.append( "ifEmpty=" ); - buf.append( getIfEmpty() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueDeleteOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueDeleteOkBodyImpl.java deleted file mode 100644 index 54eea482fa..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueueDeleteOkBodyImpl.java +++ /dev/null @@ -1,111 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueueDeleteOkBodyImpl extends AMQMethodBody_8_0 implements QueueDeleteOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueueDeleteOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 41; - - // Fields declared in specification - private final long _messageCount; // [messageCount] - - // Constructor - public QueueDeleteOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _messageCount = readUnsignedInteger( buffer ); - } - - public QueueDeleteOkBodyImpl( - long messageCount - ) - { - _messageCount = messageCount; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getMessageCount() - { - return _messageCount; - } - - protected int getBodySize() - { - int size = 4; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _messageCount ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchQueueDeleteOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueueDeleteOkBodyImpl: "); - buf.append( "messageCount=" ); - buf.append( getMessageCount() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueuePurgeBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueuePurgeBodyImpl.java deleted file mode 100644 index ae4f9d3483..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueuePurgeBodyImpl.java +++ /dev/null @@ -1,141 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueuePurgeBodyImpl extends AMQMethodBody_8_0 implements QueuePurgeBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueuePurgeBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final byte _bitfield0; // [nowait] - - // Constructor - public QueuePurgeBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public QueuePurgeBodyImpl( - int ticket, - AMQShortString queue, - boolean nowait - ) - { - _ticket = ticket; - _queue = queue; - byte bitfield0 = (byte)0; - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchQueuePurge(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueuePurgeBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueuePurgeOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueuePurgeOkBodyImpl.java deleted file mode 100644 index 576e175044..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/QueuePurgeOkBodyImpl.java +++ /dev/null @@ -1,111 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class QueuePurgeOkBodyImpl extends AMQMethodBody_8_0 implements QueuePurgeOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new QueuePurgeOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 50; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final long _messageCount; // [messageCount] - - // Constructor - public QueuePurgeOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _messageCount = readUnsignedInteger( buffer ); - } - - public QueuePurgeOkBodyImpl( - long messageCount - ) - { - _messageCount = messageCount; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getMessageCount() - { - return _messageCount; - } - - protected int getBodySize() - { - int size = 4; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _messageCount ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchQueuePurgeOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[QueuePurgeOkBodyImpl: "); - buf.append( "messageCount=" ); - buf.append( getMessageCount() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ServerMethodDispatcher_8_0.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ServerMethodDispatcher_8_0.java deleted file mode 100644 index 5c8ad68cd0..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/ServerMethodDispatcher_8_0.java +++ /dev/null @@ -1,92 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.AMQException; -import org.apache.qpid.framing.*; - - -public interface ServerMethodDispatcher_8_0 extends ServerMethodDispatcher -{ - - public boolean dispatchAccessRequest(AccessRequestBody body, int channelId) throws AMQException; - public boolean dispatchBasicAck(BasicAckBody body, int channelId) throws AMQException; - public boolean dispatchBasicCancel(BasicCancelBody body, int channelId) throws AMQException; - public boolean dispatchBasicConsume(BasicConsumeBody body, int channelId) throws AMQException; - public boolean dispatchBasicGet(BasicGetBody body, int channelId) throws AMQException; - public boolean dispatchBasicPublish(BasicPublishBody body, int channelId) throws AMQException; - public boolean dispatchBasicQos(BasicQosBody body, int channelId) throws AMQException; - public boolean dispatchBasicRecover(BasicRecoverBody body, int channelId) throws AMQException; - public boolean dispatchBasicReject(BasicRejectBody body, int channelId) throws AMQException; - public boolean dispatchChannelClose(ChannelCloseBody body, int channelId) throws AMQException; - public boolean dispatchChannelCloseOk(ChannelCloseOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelFlow(ChannelFlowBody body, int channelId) throws AMQException; - public boolean dispatchChannelFlowOk(ChannelFlowOkBody body, int channelId) throws AMQException; - public boolean dispatchChannelOpen(ChannelOpenBody body, int channelId) throws AMQException; - public boolean dispatchConnectionClose(ConnectionCloseBody body, int channelId) throws AMQException; - public boolean dispatchConnectionCloseOk(ConnectionCloseOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionOpen(ConnectionOpenBody body, int channelId) throws AMQException; - public boolean dispatchConnectionSecureOk(ConnectionSecureOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionStartOk(ConnectionStartOkBody body, int channelId) throws AMQException; - public boolean dispatchConnectionTuneOk(ConnectionTuneOkBody body, int channelId) throws AMQException; - public boolean dispatchDtxSelect(DtxSelectBody body, int channelId) throws AMQException; - public boolean dispatchDtxStart(DtxStartBody body, int channelId) throws AMQException; - public boolean dispatchExchangeBound(ExchangeBoundBody body, int channelId) throws AMQException; - public boolean dispatchExchangeDeclare(ExchangeDeclareBody body, int channelId) throws AMQException; - public boolean dispatchExchangeDelete(ExchangeDeleteBody body, int channelId) throws AMQException; - public boolean dispatchFileAck(FileAckBody body, int channelId) throws AMQException; - public boolean dispatchFileCancel(FileCancelBody body, int channelId) throws AMQException; - public boolean dispatchFileConsume(FileConsumeBody body, int channelId) throws AMQException; - public boolean dispatchFileOpen(FileOpenBody body, int channelId) throws AMQException; - public boolean dispatchFileOpenOk(FileOpenOkBody body, int channelId) throws AMQException; - public boolean dispatchFilePublish(FilePublishBody body, int channelId) throws AMQException; - public boolean dispatchFileQos(FileQosBody body, int channelId) throws AMQException; - public boolean dispatchFileReject(FileRejectBody body, int channelId) throws AMQException; - public boolean dispatchFileStage(FileStageBody body, int channelId) throws AMQException; - public boolean dispatchQueueBind(QueueBindBody body, int channelId) throws AMQException; - public boolean dispatchQueueDeclare(QueueDeclareBody body, int channelId) throws AMQException; - public boolean dispatchQueueDelete(QueueDeleteBody body, int channelId) throws AMQException; - public boolean dispatchQueuePurge(QueuePurgeBody body, int channelId) throws AMQException; - public boolean dispatchStreamCancel(StreamCancelBody body, int channelId) throws AMQException; - public boolean dispatchStreamConsume(StreamConsumeBody body, int channelId) throws AMQException; - public boolean dispatchStreamPublish(StreamPublishBody body, int channelId) throws AMQException; - public boolean dispatchStreamQos(StreamQosBody body, int channelId) throws AMQException; - public boolean dispatchTestContent(TestContentBody body, int channelId) throws AMQException; - public boolean dispatchTestContentOk(TestContentOkBody body, int channelId) throws AMQException; - public boolean dispatchTestInteger(TestIntegerBody body, int channelId) throws AMQException; - public boolean dispatchTestIntegerOk(TestIntegerOkBody body, int channelId) throws AMQException; - public boolean dispatchTestString(TestStringBody body, int channelId) throws AMQException; - public boolean dispatchTestStringOk(TestStringOkBody body, int channelId) throws AMQException; - public boolean dispatchTestTable(TestTableBody body, int channelId) throws AMQException; - public boolean dispatchTestTableOk(TestTableOkBody body, int channelId) throws AMQException; - public boolean dispatchTunnelRequest(TunnelRequestBody body, int channelId) throws AMQException; - public boolean dispatchTxCommit(TxCommitBody body, int channelId) throws AMQException; - public boolean dispatchTxRollback(TxRollbackBody body, int channelId) throws AMQException; - public boolean dispatchTxSelect(TxSelectBody body, int channelId) throws AMQException; - -}
\ No newline at end of file diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamCancelBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamCancelBodyImpl.java deleted file mode 100644 index 80032c93da..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamCancelBodyImpl.java +++ /dev/null @@ -1,129 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamCancelBodyImpl extends AMQMethodBody_8_0 implements StreamCancelBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamCancelBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [nowait] - - // Constructor - public StreamCancelBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public StreamCancelBodyImpl( - AMQShortString consumerTag, - boolean nowait - ) - { - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 1; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchStreamCancel(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamCancelBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamCancelOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamCancelOkBodyImpl.java deleted file mode 100644 index f7d5f28269..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamCancelOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamCancelOkBodyImpl extends AMQMethodBody_8_0 implements StreamCancelOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamCancelOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public StreamCancelOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public StreamCancelOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchStreamCancelOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamCancelOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamConsumeBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamConsumeBodyImpl.java deleted file mode 100644 index 2e55068f1d..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamConsumeBodyImpl.java +++ /dev/null @@ -1,180 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamConsumeBodyImpl extends AMQMethodBody_8_0 implements StreamConsumeBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamConsumeBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _queue; // [queue] - private final AMQShortString _consumerTag; // [consumerTag] - private final byte _bitfield0; // [noLocal, exclusive, nowait] - - // Constructor - public StreamConsumeBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _queue = readAMQShortString( buffer ); - _consumerTag = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public StreamConsumeBodyImpl( - int ticket, - AMQShortString queue, - AMQShortString consumerTag, - boolean noLocal, - boolean exclusive, - boolean nowait - ) - { - _ticket = ticket; - _queue = queue; - _consumerTag = consumerTag; - byte bitfield0 = (byte)0; - if( noLocal ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( exclusive ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - - if( nowait ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 2)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getQueue() - { - return _queue; - } - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final boolean getNoLocal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getExclusive() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - public final boolean getNowait() - { - return (((int)(_bitfield0)) & ( 1 << 2)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _queue ); - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _queue ); - writeAMQShortString( buffer, _consumerTag ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchStreamConsume(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamConsumeBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append( ", " ); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "noLocal=" ); - buf.append( getNoLocal() ); - buf.append( ", " ); - buf.append( "exclusive=" ); - buf.append( getExclusive() ); - buf.append( ", " ); - buf.append( "nowait=" ); - buf.append( getNowait() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamConsumeOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamConsumeOkBodyImpl.java deleted file mode 100644 index 052efc1fdd..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamConsumeOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamConsumeOkBodyImpl extends AMQMethodBody_8_0 implements StreamConsumeOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamConsumeOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - - // Constructor - public StreamConsumeOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - } - - public StreamConsumeOkBodyImpl( - AMQShortString consumerTag - ) - { - _consumerTag = consumerTag; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _consumerTag ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchStreamConsumeOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamConsumeOkBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamDeliverBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamDeliverBodyImpl.java deleted file mode 100644 index 8bbde690a0..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamDeliverBodyImpl.java +++ /dev/null @@ -1,150 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamDeliverBodyImpl extends AMQMethodBody_8_0 implements StreamDeliverBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamDeliverBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 60; - - // Fields declared in specification - private final AMQShortString _consumerTag; // [consumerTag] - private final long _deliveryTag; // [deliveryTag] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _queue; // [queue] - - // Constructor - public StreamDeliverBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _consumerTag = readAMQShortString( buffer ); - _deliveryTag = readLong( buffer ); - _exchange = readAMQShortString( buffer ); - _queue = readAMQShortString( buffer ); - } - - public StreamDeliverBodyImpl( - AMQShortString consumerTag, - long deliveryTag, - AMQShortString exchange, - AMQShortString queue - ) - { - _consumerTag = consumerTag; - _deliveryTag = deliveryTag; - _exchange = exchange; - _queue = queue; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getConsumerTag() - { - return _consumerTag; - } - public final long getDeliveryTag() - { - return _deliveryTag; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getQueue() - { - return _queue; - } - - protected int getBodySize() - { - int size = 8; - size += getSizeOf( _consumerTag ); - size += getSizeOf( _exchange ); - size += getSizeOf( _queue ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _consumerTag ); - writeLong( buffer, _deliveryTag ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _queue ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchStreamDeliver(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamDeliverBodyImpl: "); - buf.append( "consumerTag=" ); - buf.append( getConsumerTag() ); - buf.append( ", " ); - buf.append( "deliveryTag=" ); - buf.append( getDeliveryTag() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "queue=" ); - buf.append( getQueue() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamPublishBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamPublishBodyImpl.java deleted file mode 100644 index 6977e839ff..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamPublishBodyImpl.java +++ /dev/null @@ -1,167 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamPublishBodyImpl extends AMQMethodBody_8_0 implements StreamPublishBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamPublishBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 40; - - // Fields declared in specification - private final int _ticket; // [ticket] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - private final byte _bitfield0; // [mandatory, immediate] - - // Constructor - public StreamPublishBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _ticket = readUnsignedShort( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public StreamPublishBodyImpl( - int ticket, - AMQShortString exchange, - AMQShortString routingKey, - boolean mandatory, - boolean immediate - ) - { - _ticket = ticket; - _exchange = exchange; - _routingKey = routingKey; - byte bitfield0 = (byte)0; - if( mandatory ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - - if( immediate ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 1)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getTicket() - { - return _ticket; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - public final boolean getMandatory() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - public final boolean getImmediate() - { - return (((int)(_bitfield0)) & ( 1 << 1)) != 0; - } - - protected int getBodySize() - { - int size = 3; - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _ticket ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchStreamPublish(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamPublishBodyImpl: "); - buf.append( "ticket=" ); - buf.append( getTicket() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append( ", " ); - buf.append( "mandatory=" ); - buf.append( getMandatory() ); - buf.append( ", " ); - buf.append( "immediate=" ); - buf.append( getImmediate() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamQosBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamQosBodyImpl.java deleted file mode 100644 index 50fe23c170..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamQosBodyImpl.java +++ /dev/null @@ -1,152 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamQosBodyImpl extends AMQMethodBody_8_0 implements StreamQosBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamQosBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final long _prefetchSize; // [prefetchSize] - private final int _prefetchCount; // [prefetchCount] - private final long _consumeRate; // [consumeRate] - private final byte _bitfield0; // [global] - - // Constructor - public StreamQosBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _prefetchSize = readUnsignedInteger( buffer ); - _prefetchCount = readUnsignedShort( buffer ); - _consumeRate = readUnsignedInteger( buffer ); - _bitfield0 = readBitfield( buffer ); - } - - public StreamQosBodyImpl( - long prefetchSize, - int prefetchCount, - long consumeRate, - boolean global - ) - { - _prefetchSize = prefetchSize; - _prefetchCount = prefetchCount; - _consumeRate = consumeRate; - byte bitfield0 = (byte)0; - if( global ) - { - bitfield0 = (byte) (((int) bitfield0) | (1 << 0)); - } - _bitfield0 = bitfield0; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getPrefetchSize() - { - return _prefetchSize; - } - public final int getPrefetchCount() - { - return _prefetchCount; - } - public final long getConsumeRate() - { - return _consumeRate; - } - public final boolean getGlobal() - { - return (((int)(_bitfield0)) & ( 1 << 0)) != 0; - } - - protected int getBodySize() - { - int size = 11; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _prefetchSize ); - writeUnsignedShort( buffer, _prefetchCount ); - writeUnsignedInteger( buffer, _consumeRate ); - writeBitfield( buffer, _bitfield0 ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchStreamQos(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamQosBodyImpl: "); - buf.append( "prefetchSize=" ); - buf.append( getPrefetchSize() ); - buf.append( ", " ); - buf.append( "prefetchCount=" ); - buf.append( getPrefetchCount() ); - buf.append( ", " ); - buf.append( "consumeRate=" ); - buf.append( getConsumeRate() ); - buf.append( ", " ); - buf.append( "global=" ); - buf.append( getGlobal() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamQosOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamQosOkBodyImpl.java deleted file mode 100644 index 6f8977e4eb..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamQosOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamQosOkBodyImpl extends AMQMethodBody_8_0 implements StreamQosOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamQosOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public StreamQosOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public StreamQosOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchStreamQosOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamQosOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamReturnBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamReturnBodyImpl.java deleted file mode 100644 index 7b79956958..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/StreamReturnBodyImpl.java +++ /dev/null @@ -1,150 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class StreamReturnBodyImpl extends AMQMethodBody_8_0 implements StreamReturnBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new StreamReturnBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 80; - public static final int METHOD_ID = 50; - - // Fields declared in specification - private final int _replyCode; // [replyCode] - private final AMQShortString _replyText; // [replyText] - private final AMQShortString _exchange; // [exchange] - private final AMQShortString _routingKey; // [routingKey] - - // Constructor - public StreamReturnBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _replyCode = readUnsignedShort( buffer ); - _replyText = readAMQShortString( buffer ); - _exchange = readAMQShortString( buffer ); - _routingKey = readAMQShortString( buffer ); - } - - public StreamReturnBodyImpl( - int replyCode, - AMQShortString replyText, - AMQShortString exchange, - AMQShortString routingKey - ) - { - _replyCode = replyCode; - _replyText = replyText; - _exchange = exchange; - _routingKey = routingKey; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final int getReplyCode() - { - return _replyCode; - } - public final AMQShortString getReplyText() - { - return _replyText; - } - public final AMQShortString getExchange() - { - return _exchange; - } - public final AMQShortString getRoutingKey() - { - return _routingKey; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _replyText ); - size += getSizeOf( _exchange ); - size += getSizeOf( _routingKey ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedShort( buffer, _replyCode ); - writeAMQShortString( buffer, _replyText ); - writeAMQShortString( buffer, _exchange ); - writeAMQShortString( buffer, _routingKey ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchStreamReturn(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[StreamReturnBodyImpl: "); - buf.append( "replyCode=" ); - buf.append( getReplyCode() ); - buf.append( ", " ); - buf.append( "replyText=" ); - buf.append( getReplyText() ); - buf.append( ", " ); - buf.append( "exchange=" ); - buf.append( getExchange() ); - buf.append( ", " ); - buf.append( "routingKey=" ); - buf.append( getRoutingKey() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestContentBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestContentBodyImpl.java deleted file mode 100644 index 832ee12e2c..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestContentBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TestContentBodyImpl extends AMQMethodBody_8_0 implements TestContentBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TestContentBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 40; - - // Fields declared in specification - - // Constructor - public TestContentBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TestContentBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTestContent(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TestContentBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestContentOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestContentOkBodyImpl.java deleted file mode 100644 index 32c9e92c2f..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestContentOkBodyImpl.java +++ /dev/null @@ -1,111 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TestContentOkBodyImpl extends AMQMethodBody_8_0 implements TestContentOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TestContentOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 41; - - // Fields declared in specification - private final long _contentChecksum; // [contentChecksum] - - // Constructor - public TestContentOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _contentChecksum = readUnsignedInteger( buffer ); - } - - public TestContentOkBodyImpl( - long contentChecksum - ) - { - _contentChecksum = contentChecksum; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getContentChecksum() - { - return _contentChecksum; - } - - protected int getBodySize() - { - int size = 4; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedInteger( buffer, _contentChecksum ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTestContentOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TestContentOkBodyImpl: "); - buf.append( "contentChecksum=" ); - buf.append( getContentChecksum() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestIntegerBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestIntegerBodyImpl.java deleted file mode 100644 index 8d01d2d4d8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestIntegerBodyImpl.java +++ /dev/null @@ -1,159 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TestIntegerBodyImpl extends AMQMethodBody_8_0 implements TestIntegerBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TestIntegerBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final short _integer1; // [integer1] - private final int _integer2; // [integer2] - private final long _integer3; // [integer3] - private final long _integer4; // [integer4] - private final short _operation; // [operation] - - // Constructor - public TestIntegerBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _integer1 = readUnsignedByte( buffer ); - _integer2 = readUnsignedShort( buffer ); - _integer3 = readUnsignedInteger( buffer ); - _integer4 = readLong( buffer ); - _operation = readUnsignedByte( buffer ); - } - - public TestIntegerBodyImpl( - short integer1, - int integer2, - long integer3, - long integer4, - short operation - ) - { - _integer1 = integer1; - _integer2 = integer2; - _integer3 = integer3; - _integer4 = integer4; - _operation = operation; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final short getInteger1() - { - return _integer1; - } - public final int getInteger2() - { - return _integer2; - } - public final long getInteger3() - { - return _integer3; - } - public final long getInteger4() - { - return _integer4; - } - public final short getOperation() - { - return _operation; - } - - protected int getBodySize() - { - int size = 16; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeUnsignedByte( buffer, _integer1 ); - writeUnsignedShort( buffer, _integer2 ); - writeUnsignedInteger( buffer, _integer3 ); - writeLong( buffer, _integer4 ); - writeUnsignedByte( buffer, _operation ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTestInteger(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TestIntegerBodyImpl: "); - buf.append( "integer1=" ); - buf.append( getInteger1() ); - buf.append( ", " ); - buf.append( "integer2=" ); - buf.append( getInteger2() ); - buf.append( ", " ); - buf.append( "integer3=" ); - buf.append( getInteger3() ); - buf.append( ", " ); - buf.append( "integer4=" ); - buf.append( getInteger4() ); - buf.append( ", " ); - buf.append( "operation=" ); - buf.append( getOperation() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestIntegerOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestIntegerOkBodyImpl.java deleted file mode 100644 index b46b6c74d4..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestIntegerOkBodyImpl.java +++ /dev/null @@ -1,111 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TestIntegerOkBodyImpl extends AMQMethodBody_8_0 implements TestIntegerOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TestIntegerOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 11; - - // Fields declared in specification - private final long _result; // [result] - - // Constructor - public TestIntegerOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _result = readLong( buffer ); - } - - public TestIntegerOkBodyImpl( - long result - ) - { - _result = result; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getResult() - { - return _result; - } - - protected int getBodySize() - { - int size = 8; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _result ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTestIntegerOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TestIntegerOkBodyImpl: "); - buf.append( "result=" ); - buf.append( getResult() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestStringBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestStringBodyImpl.java deleted file mode 100644 index 8bdb72d58a..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestStringBodyImpl.java +++ /dev/null @@ -1,137 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TestStringBodyImpl extends AMQMethodBody_8_0 implements TestStringBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TestStringBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 20; - - // Fields declared in specification - private final AMQShortString _string1; // [string1] - private final byte[] _string2; // [string2] - private final short _operation; // [operation] - - // Constructor - public TestStringBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _string1 = readAMQShortString( buffer ); - _string2 = readBytes( buffer ); - _operation = readUnsignedByte( buffer ); - } - - public TestStringBodyImpl( - AMQShortString string1, - byte[] string2, - short operation - ) - { - _string1 = string1; - _string2 = string2; - _operation = operation; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final AMQShortString getString1() - { - return _string1; - } - public final byte[] getString2() - { - return _string2; - } - public final short getOperation() - { - return _operation; - } - - protected int getBodySize() - { - int size = 1; - size += getSizeOf( _string1 ); - size += getSizeOf( _string2 ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeAMQShortString( buffer, _string1 ); - writeBytes( buffer, _string2 ); - writeUnsignedByte( buffer, _operation ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTestString(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TestStringBodyImpl: "); - buf.append( "string1=" ); - buf.append( getString1() ); - buf.append( ", " ); - buf.append( "string2=" ); - buf.append( getString2() == null ? "null" : java.util.Arrays.toString( getString2() ) ); - buf.append( ", " ); - buf.append( "operation=" ); - buf.append( getOperation() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestStringOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestStringOkBodyImpl.java deleted file mode 100644 index be927e13ea..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestStringOkBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TestStringOkBodyImpl extends AMQMethodBody_8_0 implements TestStringOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TestStringOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 21; - - // Fields declared in specification - private final byte[] _result; // [result] - - // Constructor - public TestStringOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _result = readBytes( buffer ); - } - - public TestStringOkBodyImpl( - byte[] result - ) - { - _result = result; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final byte[] getResult() - { - return _result; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _result ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeBytes( buffer, _result ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTestStringOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TestStringOkBodyImpl: "); - buf.append( "result=" ); - buf.append( getResult() == null ? "null" : java.util.Arrays.toString( getResult() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestTableBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestTableBodyImpl.java deleted file mode 100644 index 5c4b9e8d33..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestTableBodyImpl.java +++ /dev/null @@ -1,136 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TestTableBodyImpl extends AMQMethodBody_8_0 implements TestTableBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TestTableBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 30; - - // Fields declared in specification - private final FieldTable _table; // [table] - private final short _integerOp; // [integerOp] - private final short _stringOp; // [stringOp] - - // Constructor - public TestTableBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _table = readFieldTable( buffer ); - _integerOp = readUnsignedByte( buffer ); - _stringOp = readUnsignedByte( buffer ); - } - - public TestTableBodyImpl( - FieldTable table, - short integerOp, - short stringOp - ) - { - _table = table; - _integerOp = integerOp; - _stringOp = stringOp; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final FieldTable getTable() - { - return _table; - } - public final short getIntegerOp() - { - return _integerOp; - } - public final short getStringOp() - { - return _stringOp; - } - - protected int getBodySize() - { - int size = 2; - size += getSizeOf( _table ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeFieldTable( buffer, _table ); - writeUnsignedByte( buffer, _integerOp ); - writeUnsignedByte( buffer, _stringOp ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTestTable(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TestTableBodyImpl: "); - buf.append( "table=" ); - buf.append( getTable() ); - buf.append( ", " ); - buf.append( "integerOp=" ); - buf.append( getIntegerOp() ); - buf.append( ", " ); - buf.append( "stringOp=" ); - buf.append( getStringOp() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestTableOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestTableOkBodyImpl.java deleted file mode 100644 index ea16a3b157..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TestTableOkBodyImpl.java +++ /dev/null @@ -1,124 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TestTableOkBodyImpl extends AMQMethodBody_8_0 implements TestTableOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TestTableOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 120; - public static final int METHOD_ID = 31; - - // Fields declared in specification - private final long _integerResult; // [integerResult] - private final byte[] _stringResult; // [stringResult] - - // Constructor - public TestTableOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _integerResult = readLong( buffer ); - _stringResult = readBytes( buffer ); - } - - public TestTableOkBodyImpl( - long integerResult, - byte[] stringResult - ) - { - _integerResult = integerResult; - _stringResult = stringResult; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final long getIntegerResult() - { - return _integerResult; - } - public final byte[] getStringResult() - { - return _stringResult; - } - - protected int getBodySize() - { - int size = 8; - size += getSizeOf( _stringResult ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeLong( buffer, _integerResult ); - writeBytes( buffer, _stringResult ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTestTableOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TestTableOkBodyImpl: "); - buf.append( "integerResult=" ); - buf.append( getIntegerResult() ); - buf.append( ", " ); - buf.append( "stringResult=" ); - buf.append( getStringResult() == null ? "null" : java.util.Arrays.toString( getStringResult() ) ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TunnelRequestBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TunnelRequestBodyImpl.java deleted file mode 100644 index 5bb0e64ec8..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TunnelRequestBodyImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TunnelRequestBodyImpl extends AMQMethodBody_8_0 implements TunnelRequestBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TunnelRequestBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 110; - public static final int METHOD_ID = 10; - - // Fields declared in specification - private final FieldTable _metaData; // [metaData] - - // Constructor - public TunnelRequestBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - _metaData = readFieldTable( buffer ); - } - - public TunnelRequestBodyImpl( - FieldTable metaData - ) - { - _metaData = metaData; - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - public final FieldTable getMetaData() - { - return _metaData; - } - - protected int getBodySize() - { - int size = 0; - size += getSizeOf( _metaData ); - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - writeFieldTable( buffer, _metaData ); - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTunnelRequest(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TunnelRequestBodyImpl: "); - buf.append( "metaData=" ); - buf.append( getMetaData() ); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxCommitBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxCommitBodyImpl.java deleted file mode 100644 index 096c401c02..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxCommitBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxCommitBodyImpl extends AMQMethodBody_8_0 implements TxCommitBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxCommitBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 20; - - // Fields declared in specification - - // Constructor - public TxCommitBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxCommitBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTxCommit(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxCommitBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxCommitOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxCommitOkBodyImpl.java deleted file mode 100644 index 76274be34a..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxCommitOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxCommitOkBodyImpl extends AMQMethodBody_8_0 implements TxCommitOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxCommitOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 21; - - // Fields declared in specification - - // Constructor - public TxCommitOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxCommitOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTxCommitOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxCommitOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxRollbackBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxRollbackBodyImpl.java deleted file mode 100644 index f68f881861..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxRollbackBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxRollbackBodyImpl extends AMQMethodBody_8_0 implements TxRollbackBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxRollbackBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 30; - - // Fields declared in specification - - // Constructor - public TxRollbackBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxRollbackBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTxRollback(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxRollbackBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxRollbackOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxRollbackOkBodyImpl.java deleted file mode 100644 index 7ec3d8b83b..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxRollbackOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxRollbackOkBodyImpl extends AMQMethodBody_8_0 implements TxRollbackOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxRollbackOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 31; - - // Fields declared in specification - - // Constructor - public TxRollbackOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxRollbackOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTxRollbackOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxRollbackOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxSelectBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxSelectBodyImpl.java deleted file mode 100644 index 69f4dd2ec5..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxSelectBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxSelectBodyImpl extends AMQMethodBody_8_0 implements TxSelectBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxSelectBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 10; - - // Fields declared in specification - - // Constructor - public TxSelectBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxSelectBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTxSelect(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxSelectBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxSelectOkBodyImpl.java b/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxSelectOkBodyImpl.java deleted file mode 100644 index fc1279c908..0000000000 --- a/qpid/java/common/src/main/java/org/apache/qpid/framing/amqp_8_0/TxSelectOkBodyImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -/* - * - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - * - */ - -/* - * This file is auto-generated by Qpid Gentools v.0.1 - do not modify. - * Supported AMQP version: - * 8-0 - */ - -package org.apache.qpid.framing.amqp_8_0; - -import org.apache.qpid.codec.MarkableDataInput; -import java.io.DataOutput; -import java.io.IOException; - -import org.apache.qpid.framing.*; -import org.apache.qpid.AMQException; - -public class TxSelectOkBodyImpl extends AMQMethodBody_8_0 implements TxSelectOkBody -{ - private static final AMQMethodBodyInstanceFactory FACTORY_INSTANCE = new AMQMethodBodyInstanceFactory() - { - public AMQMethodBody newInstance(MarkableDataInput in, long size) throws AMQFrameDecodingException, IOException - { - return new TxSelectOkBodyImpl(in); - } - }; - - public static AMQMethodBodyInstanceFactory getFactory() - { - return FACTORY_INSTANCE; - } - - public static final int CLASS_ID = 90; - public static final int METHOD_ID = 11; - - // Fields declared in specification - - // Constructor - public TxSelectOkBodyImpl(MarkableDataInput buffer) throws AMQFrameDecodingException, IOException - { - } - - public TxSelectOkBodyImpl( - ) - { - } - - public int getClazz() - { - return CLASS_ID; - } - - public int getMethod() - { - return METHOD_ID; - } - - - protected int getBodySize() - { - int size = 0; - return size; - } - - public void writeMethodPayload(DataOutput buffer) throws IOException - { - } - - public boolean execute(MethodDispatcher dispatcher, int channelId) throws AMQException - { - return ((MethodDispatcher_8_0)dispatcher).dispatchTxSelectOk(this, channelId); - } - - public String toString() - { - StringBuilder buf = new StringBuilder("[TxSelectOkBodyImpl: "); - buf.append("]"); - return buf.toString(); - } - -} diff --git a/qpid/java/common/src/main/java/org/apache/qpid/transport/util/Functions.java b/qpid/java/common/src/main/java/org/apache/qpid/transport/util/Functions.java index bd3e9bbcbc..61d5f0629c 100644 --- a/qpid/java/common/src/main/java/org/apache/qpid/transport/util/Functions.java +++ b/qpid/java/common/src/main/java/org/apache/qpid/transport/util/Functions.java @@ -20,10 +20,10 @@ */ package org.apache.qpid.transport.util; -import java.nio.ByteBuffer; - import static java.lang.Math.min; +import java.nio.ByteBuffer; + /** * Functions @@ -33,6 +33,9 @@ import static java.lang.Math.min; public final class Functions { + private static final char[] HEX_CHARACTERS = + {'0', '1', '2', '3', '4', '5', '6', '7', '8', '9', 'a', 'b', 'c', 'd', 'e', 'f'}; + private Functions() { } @@ -102,4 +105,21 @@ public final class Functions return str(ByteBuffer.wrap(bytes), limit); } + public static String hex(byte[] bytes, int limit) + { + limit = Math.min(limit, bytes == null ? 0 : bytes.length); + StringBuilder sb = new StringBuilder(3 + limit*2); + for(int i = 0; i < limit; i++) + { + sb.append(HEX_CHARACTERS[(((int)bytes[i]) & 0xf0)>>4]); + sb.append(HEX_CHARACTERS[(((int)bytes[i]) & 0x0f)]); + + } + if(bytes != null && bytes.length>limit) + { + sb.append("..."); + } + return sb.toString(); + } + } diff --git a/qpid/java/common/src/test/java/org/apache/qpid/codec/AMQDecoderTest.java b/qpid/java/common/src/test/java/org/apache/qpid/codec/AMQDecoderTest.java index cd810f6b3d..51f3ce1113 100644 --- a/qpid/java/common/src/test/java/org/apache/qpid/codec/AMQDecoderTest.java +++ b/qpid/java/common/src/test/java/org/apache/qpid/codec/AMQDecoderTest.java @@ -25,7 +25,7 @@ import java.io.ByteArrayOutputStream; import java.io.DataOutputStream; import java.io.IOException; import java.nio.ByteBuffer; -import java.util.ArrayList; +import java.util.List; import junit.framework.TestCase; @@ -33,17 +33,21 @@ import org.apache.qpid.framing.AMQDataBlock; import org.apache.qpid.framing.AMQFrame; import org.apache.qpid.framing.AMQFrameDecodingException; import org.apache.qpid.framing.AMQProtocolVersionException; +import org.apache.qpid.framing.FrameCreatingMethodProcessor; import org.apache.qpid.framing.HeartbeatBody; +import org.apache.qpid.framing.ProtocolVersion; public class AMQDecoderTest extends TestCase { private AMQDecoder _decoder; + private FrameCreatingMethodProcessor _methodProcessor; public void setUp() { - _decoder = new AMQDecoder(false, null); + _methodProcessor = new FrameCreatingMethodProcessor(ProtocolVersion.v0_91); + _decoder = new ClientDecoder(_methodProcessor); } @@ -57,7 +61,8 @@ public class AMQDecoderTest extends TestCase public void testSingleFrameDecode() throws AMQProtocolVersionException, AMQFrameDecodingException, IOException { ByteBuffer msg = getHeartbeatBodyBuffer(); - ArrayList<AMQDataBlock> frames = _decoder.decodeBuffer(msg); + _decoder.decodeBuffer(msg); + List<AMQDataBlock> frames = _methodProcessor.getProcessedMethods(); if (frames.get(0) instanceof AMQFrame) { assertEquals(HeartbeatBody.FRAME.getBodyFrame().getFrameType(), ((AMQFrame) frames.get(0)).getBodyFrame().getFrameType()); @@ -77,9 +82,12 @@ public class AMQDecoderTest extends TestCase msgA.limit(msgaLimit); msg.position(msgbPos); ByteBuffer msgB = msg.slice(); - ArrayList<AMQDataBlock> frames = _decoder.decodeBuffer(msgA); + + _decoder.decodeBuffer(msgA); + List<AMQDataBlock> frames = _methodProcessor.getProcessedMethods(); assertEquals(0, frames.size()); - frames = _decoder.decodeBuffer(msgB); + + _decoder.decodeBuffer(msgB); assertEquals(1, frames.size()); if (frames.get(0) instanceof AMQFrame) { @@ -99,7 +107,8 @@ public class AMQDecoderTest extends TestCase msg.put(msgA); msg.put(msgB); msg.flip(); - ArrayList<AMQDataBlock> frames = _decoder.decodeBuffer(msg); + _decoder.decodeBuffer(msg); + List<AMQDataBlock> frames = _methodProcessor.getProcessedMethods(); assertEquals(2, frames.size()); for (AMQDataBlock frame : frames) { @@ -136,12 +145,15 @@ public class AMQDecoderTest extends TestCase sliceB.put(msgC); sliceB.flip(); msgC.limit(limit); - - ArrayList<AMQDataBlock> frames = _decoder.decodeBuffer(sliceA); + + _decoder.decodeBuffer(sliceA); + List<AMQDataBlock> frames = _methodProcessor.getProcessedMethods(); assertEquals(1, frames.size()); - frames = _decoder.decodeBuffer(sliceB); + frames.clear(); + _decoder.decodeBuffer(sliceB); assertEquals(1, frames.size()); - frames = _decoder.decodeBuffer(msgC); + frames.clear(); + _decoder.decodeBuffer(msgC); assertEquals(1, frames.size()); for (AMQDataBlock frame : frames) { diff --git a/qpid/java/common/src/test/java/org/apache/qpid/framing/abstraction/MessagePublishInfoImplTest.java b/qpid/java/common/src/test/java/org/apache/qpid/framing/abstraction/MessagePublishInfoImplTest.java index 5a57db1650..aece8ed4e2 100644 --- a/qpid/java/common/src/test/java/org/apache/qpid/framing/abstraction/MessagePublishInfoImplTest.java +++ b/qpid/java/common/src/test/java/org/apache/qpid/framing/abstraction/MessagePublishInfoImplTest.java @@ -23,16 +23,17 @@ package org.apache.qpid.framing.abstraction; import junit.framework.TestCase; import org.apache.qpid.framing.AMQShortString; +import org.apache.qpid.framing.MessagePublishInfo; public class MessagePublishInfoImplTest extends TestCase { - private MessagePublishInfoImpl _mpi; + private MessagePublishInfo _mpi; private final AMQShortString _exchange = new AMQShortString("exchange"); private final AMQShortString _routingKey = new AMQShortString("routingKey"); public void setUp() { - _mpi = new MessagePublishInfoImpl(_exchange, true, true, _routingKey); + _mpi = new MessagePublishInfo(_exchange, true, true, _routingKey); } /** Test that we can update the exchange value. */ @@ -55,7 +56,7 @@ public class MessagePublishInfoImplTest extends TestCase //Check that the set value is correct assertTrue("Set value for immediate not as expected", _mpi.isImmediate()); - MessagePublishInfoImpl mpi = new MessagePublishInfoImpl(); + MessagePublishInfo mpi = new MessagePublishInfo(); assertFalse("Default value for immediate should be false", mpi.isImmediate()); @@ -72,7 +73,7 @@ public class MessagePublishInfoImplTest extends TestCase { assertTrue("Set value for mandatory not as expected", _mpi.isMandatory()); - MessagePublishInfoImpl mpi = new MessagePublishInfoImpl(); + MessagePublishInfo mpi = new MessagePublishInfo(); assertFalse("Default value for mandatory should be false", mpi.isMandatory()); diff --git a/qpid/java/systests/src/test/java/org/apache/qpid/server/logging/ExchangeLoggingTest.java b/qpid/java/systests/src/test/java/org/apache/qpid/server/logging/ExchangeLoggingTest.java index edffa7c0c0..20a6804517 100644 --- a/qpid/java/systests/src/test/java/org/apache/qpid/server/logging/ExchangeLoggingTest.java +++ b/qpid/java/systests/src/test/java/org/apache/qpid/server/logging/ExchangeLoggingTest.java @@ -20,14 +20,8 @@ */ package org.apache.qpid.server.logging; -import org.apache.qpid.client.AMQConnection; -import org.apache.qpid.client.AMQSession; -import org.apache.qpid.client.AMQSession_0_10; -import org.apache.qpid.framing.AMQFrame; -import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.ExchangeDeleteBody; -import org.apache.qpid.framing.ExchangeDeleteOkBody; -import org.apache.qpid.framing.amqp_8_0.MethodRegistry_8_0; +import java.io.IOException; +import java.util.List; import javax.jms.Connection; import javax.jms.JMSException; @@ -35,8 +29,16 @@ import javax.jms.MessageProducer; import javax.jms.Queue; import javax.jms.Session; import javax.jms.TextMessage; -import java.io.IOException; -import java.util.List; + +import org.apache.qpid.client.AMQConnection; +import org.apache.qpid.client.AMQSession; +import org.apache.qpid.client.AMQSession_0_10; +import org.apache.qpid.framing.AMQFrame; +import org.apache.qpid.framing.AMQShortString; +import org.apache.qpid.framing.ExchangeDeleteBody; +import org.apache.qpid.framing.ExchangeDeleteOkBody; +import org.apache.qpid.framing.MethodRegistry; +import org.apache.qpid.framing.ProtocolVersion; /** * Exchange @@ -191,7 +193,7 @@ public class ExchangeLoggingTest extends AbstractTestLogging } else { - MethodRegistry_8_0 registry = new MethodRegistry_8_0(); + MethodRegistry registry = new MethodRegistry(ProtocolVersion.v8_0); ExchangeDeleteBody body = registry.createExchangeDeleteBody(0, new AMQShortString(_name), false, true); diff --git a/qpid/java/systests/src/test/java/org/apache/qpid/server/store/VirtualHostMessageStoreTest.java b/qpid/java/systests/src/test/java/org/apache/qpid/server/store/VirtualHostMessageStoreTest.java index dfc507d88a..32de06186a 100644 --- a/qpid/java/systests/src/test/java/org/apache/qpid/server/store/VirtualHostMessageStoreTest.java +++ b/qpid/java/systests/src/test/java/org/apache/qpid/server/store/VirtualHostMessageStoreTest.java @@ -41,8 +41,7 @@ import org.apache.qpid.framing.AMQShortString; import org.apache.qpid.framing.BasicContentHeaderProperties; import org.apache.qpid.framing.ContentHeaderBody; import org.apache.qpid.framing.FieldTable; -import org.apache.qpid.framing.abstraction.MessagePublishInfo; -import org.apache.qpid.framing.amqp_8_0.BasicConsumeBodyImpl; +import org.apache.qpid.framing.MessagePublishInfo; import org.apache.qpid.server.configuration.updater.TaskExecutor; import org.apache.qpid.server.configuration.updater.TaskExecutorImpl; import org.apache.qpid.server.connection.SessionPrincipal; @@ -597,9 +596,9 @@ public class VirtualHostMessageStoreTest extends QpidTestCase headers.setString("Test", "MST"); properties.setHeaders(headers); - MessagePublishInfo messageInfo = new TestMessagePublishInfo(exchange, false, false, routingKey); + MessagePublishInfo messageInfo = new MessagePublishInfo(new AMQShortString(exchange.getName()), false, false, new AMQShortString(routingKey)); - ContentHeaderBody headerBody = new ContentHeaderBody(BasicConsumeBodyImpl.CLASS_ID,0,properties,0l); + ContentHeaderBody headerBody = new ContentHeaderBody(properties,0l); MessageMetaData mmd = new MessageMetaData(messageInfo, headerBody, System.currentTimeMillis()); @@ -824,52 +823,4 @@ public class VirtualHostMessageStoreTest extends QpidTestCase assertEquals("Incorrect Message count on queue:" + queueName, messageCount, queue.getQueueDepthMessages()); } - - private class TestMessagePublishInfo implements MessagePublishInfo - { - - ExchangeImpl<?> _exchange; - boolean _immediate; - boolean _mandatory; - String _routingKey; - - TestMessagePublishInfo(ExchangeImpl<?> exchange, boolean immediate, boolean mandatory, String routingKey) - { - _exchange = exchange; - _immediate = immediate; - _mandatory = mandatory; - _routingKey = routingKey; - } - - @Override - public AMQShortString getExchange() - { - return new AMQShortString(_exchange.getName()); - } - - @Override - public void setExchange(AMQShortString exchange) - { - //no-op - } - - @Override - public boolean isImmediate() - { - return _immediate; - } - - @Override - public boolean isMandatory() - { - return _mandatory; - } - - @Override - public AMQShortString getRoutingKey() - { - return new AMQShortString(_routingKey); - } - } - } diff --git a/qpid/java/systests/src/test/java/org/apache/qpid/test/unit/close/JavaServerCloseRaceConditionTest.java b/qpid/java/systests/src/test/java/org/apache/qpid/test/unit/close/JavaServerCloseRaceConditionTest.java index b43fe35a09..3fe45143d5 100644 --- a/qpid/java/systests/src/test/java/org/apache/qpid/test/unit/close/JavaServerCloseRaceConditionTest.java +++ b/qpid/java/systests/src/test/java/org/apache/qpid/test/unit/close/JavaServerCloseRaceConditionTest.java @@ -86,8 +86,16 @@ public class JavaServerCloseRaceConditionTest extends QpidBrokerTestCase // Set no wait true so that we block the connection // Also set a different exchange class string so the attempt to declare // the exchange causes an exchange. - ExchangeDeclareBody body = session.getMethodRegistry().createExchangeDeclareBody(session.getTicket(), new AMQShortString(EXCHANGE_NAME), null, - true, false, false, false, true, null); + ExchangeDeclareBody body = session.getMethodRegistry().createExchangeDeclareBody(session.getTicket(), + new AMQShortString( + EXCHANGE_NAME), + null, + true, + false, + false, + false, + true, + null); AMQFrame exchangeDeclare = body.generateFrame(session.getChannelId()); diff --git a/qpid/java/systests/src/test/java/org/apache/qpid/transport/MaxFrameSizeTest.java b/qpid/java/systests/src/test/java/org/apache/qpid/transport/MaxFrameSizeTest.java index 322b971487..f76203887c 100644 --- a/qpid/java/systests/src/test/java/org/apache/qpid/transport/MaxFrameSizeTest.java +++ b/qpid/java/systests/src/test/java/org/apache/qpid/transport/MaxFrameSizeTest.java @@ -26,8 +26,8 @@ import java.io.IOException; import java.io.InputStream; import java.io.OutputStream; import java.net.Socket; +import java.nio.ByteBuffer; import java.nio.charset.StandardCharsets; -import java.util.ArrayList; import java.util.Collections; import java.util.List; @@ -41,22 +41,19 @@ import javax.security.sasl.Sasl; import javax.security.sasl.SaslClient; import javax.security.sasl.SaslException; -import org.apache.qpid.codec.MarkableDataInput; -import org.apache.qpid.framing.AMQBody; -import org.apache.qpid.framing.AMQDataBlockDecoder; +import org.apache.qpid.codec.AMQDecoder; +import org.apache.qpid.codec.ClientDecoder; +import org.apache.qpid.framing.AMQDataBlock; import org.apache.qpid.framing.AMQFrame; import org.apache.qpid.framing.AMQFrameDecodingException; import org.apache.qpid.framing.AMQProtocolVersionException; import org.apache.qpid.framing.AMQShortString; -import org.apache.qpid.framing.BodyFactory; -import org.apache.qpid.framing.ByteArrayDataInput; import org.apache.qpid.framing.ConnectionCloseBody; import org.apache.qpid.framing.ConnectionStartOkBody; import org.apache.qpid.framing.ConnectionTuneOkBody; import org.apache.qpid.framing.FieldTable; -import org.apache.qpid.framing.amqp_0_91.ConnectionStartOkBodyImpl; -import org.apache.qpid.framing.amqp_0_91.ConnectionTuneOkBodyImpl; -import org.apache.qpid.framing.amqp_0_91.MethodRegistry_0_91; +import org.apache.qpid.framing.FrameCreatingMethodProcessor; +import org.apache.qpid.framing.ProtocolVersion; import org.apache.qpid.jms.BrokerDetails; import org.apache.qpid.server.model.AuthenticationProvider; import org.apache.qpid.server.model.Broker; @@ -114,11 +111,11 @@ public class MaxFrameSizeTest extends QpidBrokerTestCase { @Override - public void evaluate(final Socket socket, final List<AMQFrame> frames) + public void evaluate(final Socket socket, final List<AMQDataBlock> frames) { if(!socket.isClosed()) { - AMQFrame lastFrame = frames.get(frames.size() - 1); + AMQFrame lastFrame = (AMQFrame) frames.get(frames.size() - 1); assertTrue("Connection should not be possible with a frame size < " + Constant.MIN_MAX_FRAME_SIZE, lastFrame.getBodyFrame() instanceof ConnectionCloseBody); } } @@ -163,11 +160,11 @@ public class MaxFrameSizeTest extends QpidBrokerTestCase { @Override - public void evaluate(final Socket socket, final List<AMQFrame> frames) + public void evaluate(final Socket socket, final List<AMQDataBlock> frames) { if(!socket.isClosed()) { - AMQFrame lastFrame = frames.get(frames.size() - 1); + AMQFrame lastFrame = (AMQFrame) frames.get(frames.size() - 1); assertTrue("Connection should not be possible with a frame size larger than the broker requested", lastFrame.getBodyFrame() instanceof ConnectionCloseBody); } } @@ -177,7 +174,7 @@ public class MaxFrameSizeTest extends QpidBrokerTestCase private static interface ResultEvaluator { - void evaluate(Socket socket, List<AMQFrame> frames); + void evaluate(Socket socket, List<AMQDataBlock> frames); } private void doAMQP08test(int frameSize, ResultEvaluator evaluator) @@ -220,12 +217,12 @@ public class MaxFrameSizeTest extends QpidBrokerTestCase response[i++] = b; } - ConnectionStartOkBody startOK = new ConnectionStartOkBodyImpl(new FieldTable(), AMQShortString.valueOf("PLAIN"), response, AMQShortString.valueOf("en_US")); + ConnectionStartOkBody startOK = new ConnectionStartOkBody(new FieldTable(), AMQShortString.valueOf("PLAIN"), response, AMQShortString.valueOf("en_US")); DataOutputStream dos = new DataOutputStream(os); new AMQFrame(0, startOK).writePayload(dos); dos.flush(); - ConnectionTuneOkBody tuneOk = new ConnectionTuneOkBodyImpl(256, frameSize, 0); + ConnectionTuneOkBody tuneOk = new ConnectionTuneOkBody(256, frameSize, 0); new AMQFrame(0, tuneOk).writePayload(dos); dos.flush(); socket.setSoTimeout(5000); @@ -238,26 +235,11 @@ public class MaxFrameSizeTest extends QpidBrokerTestCase } byte[] serverData = baos.toByteArray(); - ByteArrayDataInput badi = new ByteArrayDataInput(serverData); - AMQDataBlockDecoder datablockDecoder = new AMQDataBlockDecoder(); - final MethodRegistry_0_91 methodRegistry_0_91 = new MethodRegistry_0_91(); - BodyFactory methodBodyFactory = new BodyFactory() - { - @Override - public AMQBody createBody(final MarkableDataInput in, final long bodySize) - throws AMQFrameDecodingException, IOException - { - return methodRegistry_0_91.convertToBody(in, bodySize); - } - }; - - List<AMQFrame> frames = new ArrayList<>(); - while (datablockDecoder.decodable(badi)) - { - frames.add(datablockDecoder.createAndPopulateFrame(methodBodyFactory, badi)); - } + final FrameCreatingMethodProcessor methodProcessor = new FrameCreatingMethodProcessor(ProtocolVersion.v0_91); + AMQDecoder decoder = new ClientDecoder(methodProcessor); + decoder.decodeBuffer(ByteBuffer.wrap(serverData)); - evaluator.evaluate(socket, frames); + evaluator.evaluate(socket, methodProcessor.getProcessedMethods()); } private static class TestClientDelegate extends ClientDelegate |
