You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@qpid.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2012/06/22 20:04:31 UTC

Build failed in Jenkins: Qpid-Java-Java-Test-IBMJDK1.6 #128

See <https://builds.apache.org/job/Qpid-Java-Java-Test-IBMJDK1.6/128/changes>

Changes:

[gsim] QPID-4075: Raise delete event for autodeleted queues also

[rgodfrey] QPID-4081: [Java Tests] Applied patch supplied by Alex Rudyy

[chug] NO-JIRA 0.18 release - add an EXTRA_DIST file required for windows builds

[aconway] QPID-4082: cluster de-sync after broker restart & queue replication

Having queue state replication between 2 clusters, restarting a broker in both
source+destination clusters sometimes leads to cluster de-sync. No QMF
communication is involved, though symptoms are similar to the bug caused by
missing propagation of QMF errors within a cluster.

The bug is caused by "deliveryCount" in SemanticState::ConsumerImpl
(qpid/broker/SemanticState.cpp) not being replicated to a joining cluster node
during catch-up. When the elder broker in src.cluster sends session.sync() after
sending 5 messages (per --ack 5 in qpid-route), the recently joiner node in
src.cluster does not do so, what leads to the cluster de-sync.

The patch:

 - adds to "consumer-state" method (see xml/cluster.xml file change) to update a new joi-ner a new property deliveryCount
 - updates cluster::Connection::consumerState to send deliveryCount to the method
 - updates cluster::Connection::consumerState to set the received deliveryCount
 - add two methods to broker::SemanticState::ConsumerImpl for getting and setting deliveryCount

[kwall] QPID-4080: [Java Broker] HA - Increase client connectdelay to allow test to be successful on slowe boxes

[gsim] QPID-3333: Patch 0015 from Anthony Foglia; better exception translation

[gsim] QPID-4076: Patch from Andy Goldstein, don't use infinite credit on bridges with explicit acknolwedgements

[chug] QPID-3902 log category - force log statement to be in test category and to display [Test] with no external processing.

[kgiusti] QPID-4063: remove spurious whitespace introduced in last commit.

[kgiusti] QPID-4063: allow configuration of source queue for exchange or dynamic routes

[aconway] NO-JIRA: Updates to HA documentation.

[aconway] QPID-4072: HA use backup messages in failover.

ReplicatingSubscription syncs the primary and backup queues, and does not
re-send messages that are already on the backup.

[aconway] NO-JIRA: Remove non-existing file windows/MemStat.cpp from ha.mk.

[aconway] QPID-3603: Fix & clean up in HA code.

- Fix fencepost error in getFirstSafe()
- QueueGuard::attach completes messages before the ReplicatingSubscription postion
- Fix minor test issues in brokertest.py and ha_test.py.
- ReplicatingSubscription check for ready in acknowledge not dispatch.
- HA test fix: retry wait_status retry on ConnectErrors, broker may not be up.

[aconway] QPID-3603: Minor cleanup and test improvements in HA code.

- Enabled 10 queue failover test
- Minor cleanup in types.h
- Rewording, adding comments.
- Detect and reject invalid replication values.
- Cleaned up some unnecessary #includes

[aconway] NO-JIRA: Remove non-existing file HeldQueue from ha.mk.

[gsim] QPID-4030: Check send rate actually achieved and report if it fails to match the desired rate

[tross] QPID-4060 - Fixed error in the help text.

[aconway] NO-JIRA: Added missing EXTERN declaration on broker::Link::getRemoteAddress

[cliffjansen] QPID-4071: basic porting changes for solaris native compiler

[chug] QPID-4022 C++ Broker connection limits corrections for cluster.
Never throw in event of shadow connection going over any limit and issue error messages describing cluster decisions.

[tross] QPID-4070 - Minor internal-api changes for LinkRegistry and Bridge (in qpid::broker)

[tross] QPID-4066 - Allow configuration to override the broker's federation tag

[kwall] QPID-4069: DistributedClientTest.testClientFailsToCreateProducerUsingInvalidSession occasionally seen to fail on CI

Test is seen to fail on slower CI boxes running persistent profiles.  From the logs, it can be seen that the
issue is timing. Extending receive timeout and sync'ing after the message ought to resolve the problem.

[kwall] QPID-4052: [Java Broker] Increase the number of retries that the client will use when trying to reconnect to the cluster.

[kwall] QPID-3977: ChartingUtil now generates chart-summary.html file to facilitate chart png browsing from CI server.

Applied patch from Philip Harvey <ph...@philharveyonline.com>

[kwall] QPID-3977: Add support for 3D bar/line charts; XY line charts, chart subtitles, and add Main-Class/Class-Path manifest entries to visualisation JAR to allow for convienient use from command line.

[kwall] QPID-4050: reduced verbosity of logging. Also removed unnecessary imports and casts in various perftests files.

Applied patch from Philip Harvey <ph...@philharveyonline.com>

[astitcher] QPID-4049: Linux C++ broker crashes when client connects SSL with expired certificate

[aconway] NO-JIRA: Fix build errors and warnings on windows in HA code.

[aconway] NO-JIRA: CMakeLists.txt: moved reference to pthread from HA link list to linux specific section.

[astitcher] NO-JIRA: Correct template to be strictly standards comformant (work with clang 3.1 & probably gcc 4.7)

[wprice] NO-JIRA: Simple fix to make JBoss7 compilation classpath generic

[aconway] QPID-3603: Bug fixes to HA code, passing test_failover_send_receive

- Updated HA logging messages to conform to new [Category] log format.
- QueueGuard fencepost error, set firstSafe correctly
- ReplicatingSubscription passing correct broker info to getGuard()
- Don't remove RemoteBackups on disconnect: fixes race where backup rejects connection but primary sees closed.

[tross] QPID-4065 - Remove the message's trace list during Queue::reRoute

[wprice] NO-JIRA:
    *Cleaned up JBoss7 configuration
    *Documentated cluster configuration for connection URL
    *Minor typo fixes

[aconway] NO-JIRA: Fix error in CMakeLists.txt to link ha library.

[tross] QPID-4061 - Added statistic: Number of unacknowledged messages in a session

[aconway] NO-JIRA: Fix errors in CMakeLists.txt for ha code.

[aconway] QPID-3603: HA bug fixes around transition to ready status

- Simplify QueueGuard::firstSafe calculation.
- Fix error in setting initial queues - was not checking if replicated.
- Send ready status to backups. Tests hang, deadlock in opened()->RemoteBackup on primary?
- Fix deadlock in QueueGuard.
- Don't start guards inside ConnectionObserver::opened.

[aconway] QPID-3603: Lock in Queue::getPosition.

Needed to ensure serialization of position changes with setObservers for ha plugin.

[aconway] QPID-3603: HA bug fixes around ha::QueueGuard

- Remove nested calls between QueueGuard::dequeued and ReplicatingSubscription
- ReplicatingSubscription can't start ahead of QueueGuard::getReadyPosition()
- Fix QueueGuard firstSafe calcultatoin
- Replace DequeueRemover with DequeueScanner in ReplicatingSubscription
- Removed bad assertions in ReplicatingSubscription and QueueGuard

[aconway] QPID-3603: Improvements to HA log messages, clarify primary/backp role.

[aconway] QPID-3603: Guard should not complete messages from the internal event queue.

ReplicatingSubscription::acknowledge was calling Guard::complete for messages on the
internal event queue as well as the replicated queue. Corrected to only complete
messages from the replicated queue.

[aconway] QPID-3603: Move calls to ConfigurationObserver outside of locks.

[aconway] QPID-3603: Introduced RemoteBackup to track backup status.

The primary creates RemoteBackup object for each connected or expected
backup. On first being promoted, the new primary has a RemoteBackup
for each of the known backups at the time of the failure.

The RemoteBackup manages queue guards for its backup and
tracks it's readiness.

[aconway] QPID-3603: Separate QueueGuard from ReplicatingSubscription.

QueueGuard: implements QueueObserver to delay completion of new messages.
ReplicatingSubscription: Implements subscription, sends messages & events to backup.

These were previously combined as one. QueueGuard is now separated out
so that it can be created before the ReplicatingSubscription, in
anticipation of an expected backup connecting. This is needed for 2 reasons:
- new queues must be guarded until they are backuped up.
- after a failover, all queues must be guarded until backups are ready.

[rgodfrey] QPID-4062 : [Java Tests] add misssing file from previous checkin

[tross] QPID-4060 - qpid-stat - Improve the help text to clarify use of the different display modes

[tross] QPID-4059 - qpid-printevents refactored to use the lighter-weight management library

[chug] QPID-3902 Log categories
Change "IO" to "Network", "AMQP" to "Protocol", and add "Client" category.

[aconway] NO-JIRA: Fix parsing of C++ URLs in qpid.messaging.util to handle IPv6 addresses.

[rgodfrey] QPID-4062 : [Java Tests] Java system tests sometimes fail due to JMX port already initialised (Applied patch from Philip Harvey

[aconway] NO-JIRA: Fix failing unit_test, updated for changes in log format.

The test had not been updated to account for changes to log format, adding
[Category] to front of messages.

[kgiusti] QPID-4046: set intrusive ptr to zero instead of calling reset() - compatible with older releases of boost

[rgodfrey] QPID-4055 : [Java Broker] update to latest version of BDB library

[shuston] Add missing typename. NO-JIRA

[kwall] QPID-4044: Synchronise DtxRegistry#commit and #rollback to eliminate the possibility of deadlock

[chug] QPID-3902 C++ Broker add log categories
svn merge --reintegrate from branch qpid/branches/qpid-3902/qpid

[tross] NO-JIRA - Fixed some Windows Visual Studio build errors

[wprice] QPID-4034: XASessionImpl should override resubscribe() for correct XA
failover behavior
    *Implemented resubscribe() in XASessionImpl
    *Minor cleanup, fixed typos etc

[chug] QPID-3603 add new file to CMakeLists

[chug] QPID-4022 C++ Broker connection limits by host ip and by user name.
Rework the strategy to deny connections based on configured limits.
All limits checked in one function from points in broker when the
user's authenticated name is known. Denied connections receive the
AMQP exception instead of getting the socket closed.

[robbie] QPID-4014: increase debug logging in ConflationQueueList

Applied patch from Phil Harvey <ph...@philharveyonline.com>

[kwall] QPID-3997: [Java Broker] Allow assignment of AuthenticationManager on a per-port basis

Address review comments from Rob Godfrey.

[kwall] NO-JIRA: Remove references to Message Store Tool from Java Broker docbook.

------------------------------------------
[...truncated 5764 lines...]
AU        qpid/doc/book/src/java-broker/images/3113111.png
AU        qpid/doc/book/src/java-broker/images/3113112.png
AU        qpid/doc/book/src/java-broker/images/3113113.png
AU        qpid/doc/book/src/java-broker/images/3113114.png
AU        qpid/doc/book/src/java-broker/images/3113115.png
A         qpid/doc/book/src/java-broker/images/HA-2N-ReplicaFail.png
AU        qpid/doc/book/src/java-broker/images/3113116.png
AU        qpid/doc/book/src/java-broker/images/3113117.png
AU        qpid/doc/book/src/java-broker/images/3113118.png
AU        qpid/doc/book/src/java-broker/images/3113119.png
A         qpid/doc/book/src/java-broker/images/HA-2N-SplitBrain.svg
AU        qpid/doc/book/src/java-broker/images/3113098.png
A         qpid/doc/book/src/java-broker/images/HA-2N-ReplicaFail.svg
AU        qpid/doc/book/src/java-broker/images/3113099.png
A         qpid/doc/book/src/java-broker/images/HA-2N-Normal.png
A         qpid/doc/book/src/java-broker/Qpid-JMX-Management-Console-FAQ.xml
A         qpid/doc/book/src/java-broker/Qpid-JMX-Management-Console-User-Guide.xml
A         qpid/doc/book/src/java-broker/Configuring-Qpid-JMX-Management-Console.xml
A         qpid/doc/book/src/java-broker/Qpid-Java-Broker-Management-CLI.xml
A         qpid/doc/book/src/java-broker/Qpid-Troubleshooting-Guide.xml
A         qpid/doc/book/src/java-broker/Add-New-Users.xml
A         qpid/doc/book/src/java-broker/Makefile
AU        qpid/doc/book/src/java-broker/How-to-Use-SlowConsumerDisconnect.xml
A         qpid/doc/book/src/java-broker/Configure-Java-Qpid-to-use-a-SSL-connection.xml
A         qpid/doc/book/src/qmf
A         qpid/doc/book/src/qmf/QmfIntroduction.xml
A         qpid/doc/book/src/qmf/QmfBook.xml
A         qpid/doc/book/src/cpp-broker
AU        qpid/doc/book/src/cpp-broker/HA-Queue-Replication.xml
A         qpid/doc/book/src/cpp-broker/Running-CPP-Broker.xml
A         qpid/doc/book/src/cpp-broker/Managing-CPP-Broker.xml
A         qpid/doc/book/src/cpp-broker/Using-message-groups.xml
A         qpid/doc/book/src/cpp-broker/Using-Broker-Federation.xml
A         qpid/doc/book/src/cpp-broker/Qpid-Interoperability-Documentation.xml
A         qpid/doc/book/src/cpp-broker/Cheat-Sheet-for-configuring-Exchange-Options.xml
A         qpid/doc/book/src/cpp-broker/Cheat-Sheet-for-configuring-Queue-Options.xml
AU        qpid/doc/book/src/cpp-broker/Active-Passive-Cluster.xml
A         qpid/doc/book/src/cpp-broker/LVQ.xml
A         qpid/doc/book/src/cpp-broker/Qpid-Management-Framework.xml
A         qpid/doc/book/src/cpp-broker/AMQP-Messaging-Broker-CPP-Book.xml
AU        qpid/doc/book/src/cpp-broker/Active-Active-Cluster.xml
A         qpid/doc/book/src/cpp-broker/QMF-Python-Console-Tutorial.xml
A         qpid/doc/book/src/cpp-broker/AMQP-Compatibility.xml
A         qpid/doc/book/src/cpp-broker/images
A         qpid/doc/book/src/cpp-broker/producer-flow-control.xml
A         qpid/doc/book/src/cpp-broker/Security.xml
A         qpid/doc/book/src/cpp-broker/queue-state-replication.xml
A         qpid/doc/book/src/cpp-broker/Makefile
A         qpid/doc/book/src/Makefile.inc
A         qpid/doc/book/src/images
AU        qpid/doc/book/src/images/qpid-logo.png
A         qpid/doc/book/src/common
A         qpid/doc/book/src/common/css
A         qpid/doc/book/src/common/css/style.css
A         qpid/doc/book/src/old
A         qpid/doc/book/src/old/Book-Info.xml
A         qpid/doc/book/src/old/Qpid-Book.xml
A         qpid/doc/book/src/old/Connection-URL-Format.xml
AU        qpid/doc/book/src/old/Security-Plugins.xml
A         qpid/doc/book/src/old/Book.xml
A         qpid/doc/book/src/old/QMan-Qpid-Management-bridge.xml
A         qpid/doc/book/src/old/AMQP-Java-JMS-Messaging-Client.xml
A         qpid/doc/book/src/old/AMQP.xml
A         qpid/doc/book/src/old/ACL.xml
A         qpid/doc/book/src/old/Binding-URL-Format.xml
A         qpid/doc/book/src/old/Clients.xml
A         qpid/doc/book/src/old/Broker-Java.xml
A         qpid/doc/book/src/old/Getting-Started.xml
A         qpid/doc/book/src/old/FAQ.xml
A         qpid/doc/book/src/old/Download.xml
A         qpid/doc/book/src/old/Management-Design-notes.xml
A         qpid/doc/book/src/old/SASL-Compatibility.xml
A         qpid/doc/book/src/old/AMQP-Messaging-Broker-CPP.xml
A         qpid/doc/book/src/old/Excel-AddIn.xml
A         qpid/doc/book/src/old/System-Properties.xml
A         qpid/doc/book/src/old/Java-Broker-StatusLogMessages.xml
A         qpid/doc/book/src/old/WCF.xml
A         qpid/doc/book/src/old/Introduction.xml
A         qpid/doc/book/src/old/schemas.xml
A         qpid/doc/book/src/old/PythonBrokerTest.xml
A         qpid/doc/book/src/old/AMQP-.NET-Messaging-Client.xml
A         qpid/doc/book/src/old/How-to-Use-JNDI.xml
A         qpid/doc/book/src/old/AMQP-C++-Messaging-Client.xml
A         qpid/doc/book/src/old/NET-User-Guide.xml
A         qpid/doc/book/src/old/SSL.xml
A         qpid/doc/book/src/old/AMQP-Ruby-Messaging-Client.xml
A         qpid/doc/book/src/old/AMQP-Python-Messaging-Client.xml
A         qpid/doc/book/src/old/Broker-CPP.xml
A         qpid/doc/book/src/old/Using-Qpid-with-other-JNDI-Providers.xml
A         qpid/doc/book/src/old/Java-JMS-Selector-Syntax.xml
AU        qpid/doc/book/src/old/InfoPlugin.xml
A         qpid/doc/book/src/old/Qpid-ACLs.xml
A         qpid/doc/book/src/old/Qpid-Compatibility-And-Interoperability-Book.xml
A         qpid/doc/book/Makefile
A         qpid/extras
A         qpid/extras/sasl
A         qpid/extras/sasl/m4
A         qpid/extras/sasl/m4/compiler-flags.m4
A         qpid/extras/sasl/m4/ac_pkg_swig.m4
A         qpid/extras/sasl/python
A         qpid/extras/sasl/python/python.i
A         qpid/extras/sasl/python/Makefile.am
A         qpid/extras/sasl/ruby
A         qpid/extras/sasl/ruby/ruby.i
A         qpid/extras/sasl/ruby/Makefile.am
A         qpid/extras/sasl/LICENSE
A         qpid/extras/sasl/configure.ac
A         qpid/extras/sasl/include
A         qpid/extras/sasl/include/saslwrapper.h
A         qpid/extras/sasl/src
A         qpid/extras/sasl/src/cyrus
A         qpid/extras/sasl/src/cyrus/saslwrapper.cpp
A         qpid/extras/sasl/src/Makefile.am
A         qpid/extras/sasl/src/saslwrapper.i
A         qpid/extras/sasl/Makefile.am
A         qpid/extras/sasl/build-aux
AU        qpid/extras/sasl/build-aux/config.rpath
AU        qpid/extras/sasl/build-aux/mdate-sh
AU        qpid/extras/sasl/build-aux/depcomp
AU        qpid/extras/sasl/build-aux/compile
AU        qpid/extras/sasl/build-aux/missing
AU        qpid/extras/sasl/build-aux/config.guess
AU        qpid/extras/sasl/build-aux/config.sub
AU        qpid/extras/sasl/build-aux/install-sh
AU        qpid/extras/sasl/build-aux/py-compile
AU        qpid/extras/sasl/bootstrap
A         qpid/extras/qmf
A         qpid/extras/qmf/NOTICE.txt
A         qpid/extras/qmf/LICENSE.txt
A         qpid/extras/qmf/.gitignore
AU        qpid/extras/qmf/setup.py
A         qpid/extras/qmf/src
A         qpid/extras/qmf/src/py
A         qpid/extras/qmf/src/py/qmf
A         qpid/extras/qmf/src/py/qmf/__init__.py
A         qpid/extras/qmf/src/py/qmf/console.py
A         qpid/extras/qmf/src/py/qmf2-prototype
A         qpid/extras/qmf/src/py/qmf2-prototype/common.py
A         qpid/extras/qmf/src/py/qmf2-prototype/tests
A         qpid/extras/qmf/src/py/qmf2-prototype/tests/multi_response.py
A         qpid/extras/qmf/src/py/qmf2-prototype/tests/obj_gets.py
A         qpid/extras/qmf/src/py/qmf2-prototype/tests/agent_test.py
A         qpid/extras/qmf/src/py/qmf2-prototype/tests/async_method.py
A         qpid/extras/qmf/src/py/qmf2-prototype/tests/__init__.py
A         qpid/extras/qmf/src/py/qmf2-prototype/tests/basic_method.py
A         qpid/extras/qmf/src/py/qmf2-prototype/tests/console_test.py
A         qpid/extras/qmf/src/py/qmf2-prototype/tests/async_query.py
A         qpid/extras/qmf/src/py/qmf2-prototype/tests/events.py
A         qpid/extras/qmf/src/py/qmf2-prototype/tests/agent_discovery.py
A         qpid/extras/qmf/src/py/qmf2-prototype/tests/basic_query.py
A         qpid/extras/qmf/src/py/qmf2-prototype/tests/subscriptions.py
A         qpid/extras/qmf/src/py/qmf2-prototype/agent.py
A         qpid/extras/qmf/src/py/qmf2-prototype/__init__.py
A         qpid/extras/qmf/src/py/qmf2-prototype/console.py
A         qpid/bin
A         qpid/bin/NOTICE
A         qpid/bin/LICENSE
AU        qpid/bin/install-cpp-python
AU        qpid/bin/set_svn_properties.sh
AU        qpid/bin/release.sh
AU        qpid/bin/mvn-deploy-qpid-java.sh
A         qpid/etc
A         qpid/etc/NOTICE
A         qpid/etc/LICENSE
AU        qpid/etc/svn-auto-props
A         qpid/README.txt
A         qpid/KEYS
A         qpid/specs
AU        qpid/specs/amqp.0-10-qpid-errata.xml
A         qpid/specs/NOTICE
A         qpid/specs/LICENSE
AU        qpid/specs/cluster.0-8.xml
AU        qpid/specs/amqp.0-10.dtd
AU        qpid/specs/apache-filters.xml
AU        qpid/specs/amqp.0-10-preview.xml
AU        qpid/specs/amqp.0-8.xml
A         qpid/specs/amqp.0-9.xml
AU        qpid/specs/amqp.xsl
AU        qpid/specs/amqp-nogen.0-9.xml
AU        qpid/specs/amqp.0-10.xml
AU        qpid/specs/management-schema.xml
A         qpid/specs/amqp0-9-1.stripped.xml
AU        qpid/specs/amqp-dtx-preview.0-9.xml
AU        qpid/specs/amqp-errata.0-9.xml
 U        .
At revision 1352974
[locks-and-latches] Checking to see if we really have the locks
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
[locks-and-latches] Could not get all the locks... sleeping for 1 minute
Build timed out (after 60 minutes). Marking the build as failed.
Recording test results

Jenkins build is back to normal : Qpid-Java-Java-Test-IBMJDK1.6 #129

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/Qpid-Java-Java-Test-IBMJDK1.6/129/changes>