summaryrefslogtreecommitdiff
path: root/java/client/src/test
Commit message (Collapse)AuthorAgeFilesLines
* QPID-572 patches applied.Rupert Smith2007-09-181-0/+152
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2.0.0.0_patch@576914 13f79535-47bb-0310-9956-ffa450edef68
* Update fix incorrect license headers.Martin Ritchie2007-07-181-11/+14
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@557306 13f79535-47bb-0310-9956-ffa450edef68
* Caused each of these tests to run 10 times to help identify any race ↵Martin Ritchie2007-06-272-45/+90
| | | | | | | | conditions that were occuring. Updated the CommitRollbackTest to be more robust in the detection of failure. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@551174 13f79535-47bb-0310-9956-ffa450edef68
* Various License header updates.Martin Ritchie2007-06-184-0/+84
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@548276 13f79535-47bb-0310-9956-ffa450edef68
* Removed log4j dependency from client. Using slf4j instead, end-user to ↵Rupert Smith2007-06-1133-988/+987
| | | | | | supply logging implementation as desired. Log4j used for tests. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@546190 13f79535-47bb-0310-9956-ffa450edef68
* QPID-402: FailoverException falling through to client. All blocking ↵Rupert Smith2007-06-014-143/+126
| | | | | | operations now wrapped in failover support wrappers. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@543496 13f79535-47bb-0310-9956-ffa450edef68
* QPID-466 Updated FieldTable to ensure no Decimal value is set that is larger ↵Martin Ritchie2007-05-071-1/+25
| | | | | | | | | | than can be transmitted over AMQP. That is a max scale value of Byte.MAX_VALUE and value of up to Integer.MAX_VALUE. Additional tests to ensure this is the case. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@535809 13f79535-47bb-0310-9956-ffa450edef68
* QPID-466 Changes to FieldTable along with corresponding PropertyValueTest to ↵Martin Ritchie2007-05-042-6/+42
| | | | | | limit the Java client to only AMQP 0-8 compliant values. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@535309 13f79535-47bb-0310-9956-ffa450edef68
* QPID-461 Update to CommitRollbackTest. Ensuring messages received have the ↵Martin Ritchie2007-05-011-7/+27
| | | | | | correct redelivered value, regardless of order. Different test case also was problematic. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@534036 13f79535-47bb-0310-9956-ffa450edef68
* QPID-461 Update to CommitRollbackTest. Ensuring messages received have the ↵Martin Ritchie2007-04-301-14/+14
| | | | | | correct redelivered value, regardless of order. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@533765 13f79535-47bb-0310-9956-ffa450edef68
* QPID-476 : Remove duplicate map of channelId to sessionRobert Godfrey2007-04-301-3/+0
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@533721 13f79535-47bb-0310-9956-ffa450edef68
* Updated MLT to have variables that define the BROKER and VHOST used and ↵Martin Ritchie2007-04-271-23/+30
| | | | | | White space git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@533079 13f79535-47bb-0310-9956-ffa450edef68
* ResetMessageListenerTest - needs to have IMMEDIATE_PREFETCH = true.Martin Ritchie2007-04-231-12/+11
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@531527 13f79535-47bb-0310-9956-ffa450edef68
* Comment updates on the origin of the testsMartin Ritchie2007-04-231-1/+3
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@531517 13f79535-47bb-0310-9956-ffa450edef68
* QPID-472 - Creation of TemporaryQueues will not guarantee unique queue names ↵Martin Ritchie2007-04-231-4/+131
| | | | | | | | if created rapidly. Updated TemporaryQueueTest.java so that it checks Headers/Queue/Topic for unroutable/mandatory messages beig returned. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@531512 13f79535-47bb-0310-9956-ffa450edef68
* Reinstated the two consumer receive test. Martin Ritchie2007-04-202-23/+119
| | | | | | Added additional test class to cover the IMMEDIATE_PREFETCHs. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@530683 13f79535-47bb-0310-9956-ffa450edef68
* Additional test to ensure connection closure doesn't cause problems.Martin Ritchie2007-04-191-0/+81
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@530449 13f79535-47bb-0310-9956-ffa450edef68
* Committed test with localhost as the brokerMartin Ritchie2007-04-191-5/+4
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@530447 13f79535-47bb-0310-9956-ffa450edef68
* Added Test logging to aid in diagnosing problemsMartin Ritchie2007-04-191-2/+26
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@530438 13f79535-47bb-0310-9956-ffa450edef68
* QPID-459 - NoLocal broken when messages already exist on queue from ↵Martin Ritchie2007-04-191-19/+100
| | | | | | | | | | consumer. With test. TopicSessionTest - Additional testing for NoLocal to ensure. Forgot to include the file in the commit. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@530437 13f79535-47bb-0310-9956-ffa450edef68
* QPID-455 - Guarded test with a check until a full solution is foundMartin Ritchie2007-04-181-4/+7
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@530052 13f79535-47bb-0310-9956-ffa450edef68
* ResetMessageListenerTest was using the wrong queue for running tests. This ↵Martin Ritchie2007-04-181-1/+1
| | | | | | | | was causing problems during testing. Changed queue to use ResetMessageListenerTest queue git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@530048 13f79535-47bb-0310-9956-ffa450edef68
* Fix for intermittent CRT expected <1> but was <2> errorsMartin Ritchie2007-04-181-6/+19
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@530047 13f79535-47bb-0310-9956-ffa450edef68
* QPID-457 Fixed rollback inTran problem with test caseMartin Ritchie2007-04-181-0/+31
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@530041 13f79535-47bb-0310-9956-ffa450edef68
* QPID-455 Prefetched messages can cause problems with client tools.Martin Ritchie2007-04-175-37/+81
| | | | | | | | | | | | | | | AMQSession - suspend channel at startup until start() and recieve/setMessageListener are called. BasicMessageConsumer - mainly style sheet changes MessageListenerMultiConsumerTest - removed one test case as we cannot ensure round-robin effect at start up .. added test case for only c2 consuming when c1 does nothing. MessageListenerTest - added new test that can demonstrate a further bug of message 'loss' when a receive is called only once before a message listener is set. Prefetched message end up on _SynchronousQueue regression of QPID-293 as of r501004. MessageRequeueTest - Was missing a conn.start() DurableSubscriptionTest - Removed blocking receives() so we don't block on failure CommitRollbackTest - Text message was wrong on testGetThenDisconnect tests so adjusted git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@529666 13f79535-47bb-0310-9956-ffa450edef68
* QPID-451 Throw InvalidDestinationException on attempt to publish to a Queue ↵Robert Godfrey2007-04-121-0/+109
| | | | | | | | | which does not exist Changed QueueSenderAdapter to check if the routing key is bound to a queue on the given exchange. The checking can be turned off by setting the system property org.apache.qpid.client.verifyQueueBindingBeforePublish to anything but true git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@527876 13f79535-47bb-0310-9956-ffa450edef68
* Stopped throwing away exception causes.Robert Greig2007-04-092-2/+3
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@526776 13f79535-47bb-0310-9956-ffa450edef68
* Moved broker details to a separate variable.Martin Ritchie2007-04-021-4/+10
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/branches/M2@524765 13f79535-47bb-0310-9956-ffa450edef68
* QPID-70 InVM Authentication QPID-419 Access Control QPID-423 Authentication ↵Martin Ritchie2007-03-167-32/+30
| | | | | | | | | | | | | | per virtualhost Restructured auth package. Enabled InVM Authentication Initial changes to allow authenticators per virtualhost. Initial access control classes. Initial work to allow access control testing through inVM broker. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@518988 13f79535-47bb-0310-9956-ffa450edef68
* Added close before ack test for QPID-397Robert Greig2007-03-151-0/+147
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@518700 13f79535-47bb-0310-9956-ffa450edef68
* Short pause to help ensure connection.close comes after last message ack, ↵Robert Greig2007-03-151-0/+2
| | | | | | added to PropertyValueTest git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@518667 13f79535-47bb-0310-9956-ffa450edef68
* QPID-346,QPID-386,QPID-403, QPID-410 Rollback, Basic-Reject, QueueBrowser ↵Martin Ritchie2007-03-133-290/+363
| | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | NO_ACK. QPID-346 Message loss after rollback\recover QPID-386 Updated Transactional Tests to cover underlying AMQP/Qpid state. QPID-403 Implement Basic.Reject QPID-410 Queue Browsers should use not acknowledge messages. ------------------------------------- Broker TxAck - Added comment and fixed white space UnacknowledgedMessage - Added comment for messageDecrement AMQChannel - Added extra debugging. + Created a NonTransactionalContext for requeuing messages as using txContext will tie the requeue to any runing transaction. + Updated message reference counting. So it is in terms of queues don't increment when giving to client. BasicCancelMethodHandler - Added Debug log. BasicConsumeMethodHandler - Reverted to directly writes frames to the session, throwing ChannelException caused problems. Added Trace and debug logging. BasicRejectMethodHandler, ChannelCloseHandler, ConnectionCloseMethodHandler - Added Debug logging AMQPFastProtocolHandler - moved error log to before session.write AMQMessage - Added additional debug via debugIdentity() and comments AMQQueue - Decoupled reference counting from dequeue operation. ConcurrentSelectorDeliveryManager - Added comments and increased info in debug logging SubscriptionImpl - Disabled use of acks for browsers. For now put setDeliveredToConsumer back in the finally block. commented that I'm not sure this is correct as even an error writing to client will cause msg to be marked delivered to consumer. + On Close ensured that it is only called once. + Had problem where closing browser was causing two CancelOk frames to be sent back to client. RequiredDeliveryException - Added comment to explain incrementReference LocalTransactionalContext - Commented out incrementReference as it shouldn't be required here. NonTransactionalContext - Removed incrementReference on deliver + - Fixed bug where browsers - acks would cause messages to be discarded. new JIRA this needs tidied up. TxnBuffer - Added debug logging. Client ------ AMQQueueBrowser - Added comments AMQSession - Added comments and debug + Updated to cause closed consumer to reject messages rather than receive them. + Prevented NoConsumer's from rollingback and rejecting.. they simply clear their SyncQueue - JIRA to ensure clean state with rollback BasicMessageConsumer - Added trace level debuging on close calls + Forced noConsume-rs to use NO_ACK + added more logging Closeable - Updated to use isClosed rather than directly calling _closed.get() to aid in future work on ensuring multi threaded close still allows pending acks to be processed first. ChannelCloseOkMethodHandler - updated comment AMQProtocolSession - Update comments,whitespace TransportConnection - removed static block FlowControllingBlockingQueue - Added isEmpty() Method PropertyValueTest - Added VM Broker setup + Updated test to run once and 50 times to pull out delivery tag problems that were occuring. + Adjusted logging level to be more helpful. moved some info down to trace and debug. MessageRequeueTest - Moved QpidClientConnection its own file. + Fixed it so it actually runs more than one consumer, concurrently.Now 3 was 1. ConcurrentLinkedMessageQueueAtomicSize - Implemented iterator(). Added QueueBrowserTest to system tests to test QueueBrowsering. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@517638 13f79535-47bb-0310-9956-ffa450edef68
* QPID-405 Reduce excess output during testsMartin Ritchie2007-03-0612-20/+46
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@515128 13f79535-47bb-0310-9956-ffa450edef68
* QPID-403 QPID-346 QPID-355 QPID-386 QPID-389 Updates to fix Transactional ↵Martin Ritchie2007-03-066-68/+782
| | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | Rollback. QPID-346 Message loss after rollback\recover QPID-355 Closing a consumer does not ensure messages delivery will stop for that subscription QPID-386 Updated Transactional Tests to cover underlying AMQP/Qpid state. QPID-389 Prefetched message are not correctly returned to the queue QPID-403 Implement Basic.Reject Broker UnacknowledgedMessage - Added toString for debug UnacknowledgedMessageMapImpl - Removed resendMessages method as all sending should go via DeliveryManager and Subscription. AMQChannel - Updated resend and requeue methods so they do not directly write messages to a subscriber. This was violating the suspension state. - Used a local non-transactional context to requeue messages as the internal requeuing of messages on the broker should not be part of any client transaction. - Maked messages as resent. - Removed warnings from IDE about missing JavaDoc text etc. BasicAckMethodHandler - Added debugging BasicRecoverMethodHandler - Removed session from the resend call. BasicRejectMethodHandler - Initial implementation. Hooks left for possible 'resend' bit. ChannelCloseHandler - Fixed bug where channel wasn't marked as fully closed on reception of a close from the client. TxRollbackHandler - Removed session from resend call. AMQMinaProtocolSession - Fixed bug where channel was marked as awaiting closure before it had actually been closed. This causes problems as the close looks up the channel by id again which will return null after it has been marked as awaiting closure. AMQMessage - Initial implementation of Rejection. Currently inactive in hasInterest() as we are miss-using reject to requeue prefetched messages from the client. AMQQueue - Removed debug method as it made reading the log very difficult as all the logs had the same line number ConcurrentSelectorDeliveryManager - Fixed clearAllMessages() as it didn't actually remove the messages. - Fixed bad logic in getNextMessage when using null subscriber. (as done by clearAllMessages) - Added more logging messages. Made more frequent logging a trace value. - Added debugIdentity() method to reduce over head in calculating standard log prefix. - Allowed messages to be added to the front of the queue. - Added currentStatus() to an overview of the queue's current state. SubscriptionImpl - Updated to handle closure correctly (QPID-355) -Updated the deliver method so it doesn't use a try->finally to do msg.setDeliveredToConsumer() as this would be done even in the event of an error. - Created an additional logger to log suspension calls rather than through the SI logger which logs a lot of detail. Client pom.xml - Excluded older version of log4j that commons-collections exposes. AMQSession - Added ability for dispatcher to start in stopped state. - Added dispatcher logger - Added checks around logging - Added message rejection if the dispatcher receives a message that it doesn't have a consumer for. - Updated message rejection to allow the dispatcher to perform the rejection if running this ensures that all queued messages are processed correctly and rejection occurs in order. - rollback() before calling rollback all pending queued messages must be rejected as rollback will clear unacked map which the rejects caused by rollback() will need. - fixed closedProducersAndConsumers so that it will rethrow any JMS Exception - recover() as for rollback() the rejects need to be done before the Recover Call to the broker. - Allowed delclareExchange to be done synchronously programatically - Updated confirmConsumerCancelled to use the dispatcher to perform the clean up. This required the creation of the dispatcher in stopped mode so that it does not start and message attempted to be delivered while the subscriber is being cancelled. BasicMessageConsumer - Updated close not to perform the deregistration. This is done in via BasicCancelOkMethodHandler - Added guards on logging - Record all messages that have been received so they can be rejected if rollback occurs. so had to change impl of acknowledgeLastDelivered. - Updated Rollback to initially reject all received messages that are still unAcked. - Added a recursive call should the queue not be empty at the end of the rollback.. with a warning. BasicCancelOkMethodHandler - White space changes to meet style guide. Added guard on logging. UnprocessedMessage - White space changes to meet style guide. StateWaiter - Added comment about timeout bug. FlowControllingBlockingQueue - Tidied imports RecoverTest - Updated as declareExchange is now Synchronous ChannelCloseTest - added guard on logging MessageRequeueTest - Added to better test underlying AMQP/Qpid state QPID-386 StreamMessageTest - Updated as declareExchange is now Synchronous CommitRollbackTest - added Additional test case to ensure prefetch queue is correctly purged. TransactedTest - Added logging and additional tests. Cluster SimpleClusterTest - updated in line with AMQSession.delcareExchange changes Common AMQConstant - Fixed error code 'not allowed' should be 530 not 507. ConcurrentLinkedMessageQueueAtomicSize - Updated to beable to get the size of messages on the 'head' queue along with additional debug Systests ReturnUnroutableMandatoryMessageTest - Updated as declareExchange is now Synchronous git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@515127 13f79535-47bb-0310-9956-ffa450edef68
* QPID-346 Message loss after rollbackMartin Ritchie2007-02-232-7/+390
| | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | | QPID-348 Problems of prefetching messages QPID-355 Closing a consumer does not ensure messages delivery will stop for that subscription BROKER AMQChannel - updated requeue to either resend via the Delivery Manager not directly via msg.writedeliver. BasicRejectMethodHandler - initial place holder. TxRollbackHandler - Added comment AMQMessage - added ability to record who has taken the message so that it can be resent to that subscriber on resend/requeue. AMQQueue - added the queue reference to the Subscription creation ConcurrentSelectorDeliveryManager - Added methods to correctly monitor the size of queue messages. Including messages on the resend queue of a Subscriber. Additional locking to ensure that messages are not sent to the subscriber after Closure. QPID-355 DeliveryManager - adjusted deliver call to allow delivery to the head of the queue. Subscription - changes to allow selction of queue(resend or predelivery) methods to add to resend and getSendLock to ensure that sending to the Subscription is allowed. SubscriptionFactory - changes to allow the AMQQueue to be passed to the Subscription. SubscriptionImpl - implementation of the interfaces. Local storage of messages to be resent and requeuing of the messages during closure. SubscriptionSet - changes to retrieve the actual stored Subscription when performing removeSubscriber. So we have access to the the resend queue. AMQStateManager - Added BasicRejectMethodHandler TransactionalContext - Added option to deliver the messages to the front of the queue. LocalTransactionalContext - cleared the _postComitDeliveryList on rollback. Added option to deliver the messages to the front of the queue. NonTransactionalContext - Added option to deliver the messages to the front of the queue. DeliverMessageOperation.java DELELTED AS NOT USED. CLIENT AMQSession - added ability to get the pervious state of the dispatcher when settting Stopped, fixed the channel suspension problems on broker so uncommented clean up code in rollback and recover. BasicMessageConsumer - updated the rollback so that it sends reject messages to server. AbstractJMSMessage - whitespace + added extra message properties to the toString() AMQProtocolHandler - whitespace + extra debug output TransactedTest - updated expect to prevent NPEs also added extra logging to help understand what is going on. CLUSTER ClusteredQueue - AMQQueue changes for message deliveryFirst. RemoteSubscriptionImpl - Implementation of Subscription SYSTESTS AbstractHeadersExchangeTestBase - AMQQueue changes for message deliveryFirst. AMQQueueMBeanTest - changes for message deliveryFirst. ConcurrencyTest - changes for message deliveryFirst. DeliveryManagerTest - changes for message deliveryFirst. SubscriptionTestHelper - Implementation of Subscription WhiteSpace only UnacknowledgedMessageMapImpl.java git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@510897 13f79535-47bb-0310-9956-ffa450edef68
* Renamed AMQInvalidSelectorException to be AMQInvalidArgumentException to ↵Martin Ritchie2007-02-201-4/+4
| | | | | | better fit the generic use of the argument table in the AMQP Queue.Bind spec. Adjusted AMQConstant to match the proposal for additional codes AMQP-39,40,41 (https://wiki.108.redhat.com/jira/browse/AMQP-39). git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@509478 13f79535-47bb-0310-9956-ffa450edef68
* Fully propogated timeouts during AMQConnection.close. Still needs timeouts ↵Martin Ritchie2007-02-192-99/+1
| | | | | | to be reduced between the various session closures. QPID-380 git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@509216 13f79535-47bb-0310-9956-ffa450edef68
* QPID-379 Bounced Messages do not appear in connection exception listener. Martin Ritchie2007-02-194-48/+125
| | | | | | | | | | | | The previous commit that started the Dispatcher was wrong and caused a lot of failures. This will address that problem by providing a thread pool on the client connection object to deliver bounced messages to the exception handler. Tidied up MessageListenerTests so all the asserts are in the given test. Renamed TestChannelCloseMethodHandlerNoCloseOk as surefire picks it up as a test case. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@509202 13f79535-47bb-0310-9956-ffa450edef68
* QPID-376 Renamed Test case StateManagerMartin Ritchie2007-02-191-3/+1
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@509178 13f79535-47bb-0310-9956-ffa450edef68
* QPID-376 Renamed Test case StateManagerMartin Ritchie2007-02-191-0/+108
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@509177 13f79535-47bb-0310-9956-ffa450edef68
* Badly named file annoyed surefireMartin Ritchie2007-02-191-108/+0
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@509176 13f79535-47bb-0310-9956-ffa450edef68
* QPID-372, QPID-376 Broker now ignores all frames for closing channels. Martin Ritchie2007-02-193-0/+606
| | | | | | | | | | | | | | | | | | | When a close-ok is received the channel can be reopened and used All uses of getChannel check the return type is not null and throw a NOT_FOUND AMQException. If the channel is not found during a method handler then the Channel will be closed. ChannelCloseHandler - Now throws a connection exception if trying to close a a non exisitant channel. AMQMinaProtocolSession - Added pre-check for closing channels to ignore all but Close-OK methods - Updated ChannelException method to close connection if the CE was a result of not having a valid channel. - Changed state to CLOSING when writing out a connection close frame. AMQConnection - Wrapped all _logging calls , Updated comment formatting AMQSession - called startDispatcherIfRequired when receiving a message as without it a producer will not get a returned message. This is because there is no consumer setup to consume. ConnectionCloseMethodHandler - Wrapped code in try finally so that the protocol session would always be closed correctly. AMQStateManager - Added state to the logging values Modified AMQTimeoutException to include a new constant value to identify the failure reason. AMQConstant - Added 408 REQUEST_TIMEOUT fixed error with NOT_ALLOWED value was 530 should be 507. git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@509172 13f79535-47bb-0310-9956-ffa450edef68
* QPID-375 : Default Exchange fixesRobert Godfrey2007-02-191-1/+1
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@509147 13f79535-47bb-0310-9956-ffa450edef68
* QPID-375 : remove assumptions on standard exchanges (amq.direct, amq.topic, ↵Robert Godfrey2007-02-1635-83/+173
| | | | | | etc), allow other exchanges to be created through virtualhosts.xml git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@508649 13f79535-47bb-0310-9956-ffa450edef68
* QPID-11 remove protocol literals from code. Martin Ritchie2007-02-161-1/+1
| | | | | | | | | | | | | | | | | | | | | QPID-376 use of getChannel() does not correct handle error cases when null is returned. Updated AMQMethodBody - to have a convenience method getChannelNotFoundException to be used for QPID-376 when channel is null. This allows the replyCode NOT_FOUND=404 to be changed to changed easily if required. QPID-376 - Updated All Handlers to throw channel exception when channel is null. QPID-11 Updated all handlers to use AMQConstant values rather than hardcoded literals. - Updated AMQException to use AMQConstant values rather than int to ensure that no more literal values creep back in to the code base. Replaced all usages of int above framing to store replycode with AMQConstant to prevent creep. Had to create new constants for literals used in code base but not yet part of spec. 405=Already Exists 406=In Use 323=Invalid Routing Key Remove non spec constant 500=Unknown_Exchange_Name replaced with generic NOT_FOUND git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@508381 13f79535-47bb-0310-9956-ffa450edef68
* Reset log level from error to info.Martin Ritchie2007-02-141-1/+1
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@507609 13f79535-47bb-0310-9956-ffa450edef68
* Applied QPID-162 patches from Kevin SmithMartin Ritchie2007-02-1450-285/+428
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@507595 13f79535-47bb-0310-9956-ffa450edef68
* QPID-368 Revised. Had the wrong logging level set on an log statementMartin Ritchie2007-02-141-1/+1
| | | | git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@507559 13f79535-47bb-0310-9956-ffa450edef68
* QPID-368 Added the first data body to the list when creating it. included ↵Martin Ritchie2007-02-141-0/+188
| | | | | | | | | | | | | | | | | test case. Test case tests sending 9 messages - 64k-1 - 64k - 64k+1 - 128k-1 - 128k - 128+1 - 128k - 512k - 1024k git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@507557 13f79535-47bb-0310-9956-ffa450edef68
* QPID-339 DispatcherTest.java was broker now it actually tests correctly.Martin Ritchie2007-02-012-8/+284
| | | | | | Added test to Check changing message listeners git-svn-id: https://svn.apache.org/repos/asf/incubator/qpid/trunk/qpid@502261 13f79535-47bb-0310-9956-ffa450edef68