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 2014/02/04 03:51:38 UTC

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

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

Changes:

[aconway] QPID-5528: HA add missing QPID_BROKER_EXTERN declarations.

Missing from previous commit
 r1564010 | QPID-5528: HA Clean up error messages around rolled-back transactions.

[aconway] QPID-5528: HA Clean up error messages around rolled-back transactions.

A simple transaction test on a 3 node cluster generates a lot of errors and
rollback messages in the broker logs even though the test code never rolls back a
transaction. E.g.

  qpid-cluster-benchmark -b 20.0.20.200 -n1 -m 1000 -q3 -s2 -r2 --send-arg=--tx --send-arg=10 --receive-arg=--tx --receive-arg=10

The errors are caused by queues being deleted while backup brokers are using
them. This happens a lot in the transaction test because a transactional session
must create a new transaction when the previous one closes. When the session
closes the open transaction is rolled back automatically. Thus there is almost
always an empty transaction that is created then immediately rolled back at the
end of the session. Backup brokers may still be in the process of subscribing to
the transaction's replication queue at this point, causing (harmlesss) errors.

This commit takes the following steps to clean up the unwanted error and rollback messages:

HA TX messages cleaned up:
- Remove log messages about rolling back/destroying empty transactions.
- Remove misleading "backup disconnected" message for cancelled transactions.
- Remove spurious warning about ignored unreplicated dequeues.
- Include TxReplicator destroy in QueueReplicator mutex, idempotence check before destroy.

Allow HA to suppress/modify broker exception logging:
- Move broker exception logging into ErrorListener
- Every SessionHandler has DefaultErrorListener that does the same logging as before.
- Added SessionHandlerObserver to allow plugins to change the error listener.
- HA plugin set ErrorListeners to log harmless exceptions as HA debug messages.

Unrelated cleanup:
- Broker now logs "incoming execution exceptions" as debug messages rather than ignoring.
- Exception prefixes: don't add the prefix if already present.

The exception test above should now pass without errors or rollback messages in the logs.

[gsim] NO-JIRA: minor additions to readme

[pmoravec] QPID-5519: ACL property/properties for paged queues - fixed typo, added tests and documentation

[pmoravec] QPID-5534: [C++ broker] Headers exchange can route a message to one queue multiple times

------------------------------------------
[...truncated 5049 lines...]
    [junit] Tests run: 6, Failures: 0, Errors: 0, Time elapsed: 0.455 sec
    [junit] Running org.apache.qpid.test.unit.client.MaxDeliveryCountTest
    [junit] Tests run: 7, Failures: 0, Errors: 0, Time elapsed: 3.797 sec
    [junit] Running org.apache.qpid.test.unit.client.QueueSessionFactoryTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.229 sec
    [junit] Running org.apache.qpid.test.unit.client.TopicSessionFactoryTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 0.235 sec
    [junit] Running org.apache.qpid.test.unit.client.channelclose.CloseWithBlockingReceiveTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 1.069 sec
    [junit] Running org.apache.qpid.test.unit.client.connection.BrokerClosesClientConnectionTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 12.13 sec
    [junit] Running org.apache.qpid.test.unit.client.connection.ConnectionFactoryTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.122 sec
    [junit] Running org.apache.qpid.test.unit.client.connection.ConnectionStartTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.121 sec
    [junit] Running org.apache.qpid.test.unit.client.connection.ConnectionTest
    [junit] Tests run: 12, Failures: 0, Errors: 0, Time elapsed: 1.693 sec
    [junit] Running org.apache.qpid.test.unit.client.connection.ExceptionListenerTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.151 sec
    [junit] Running org.apache.qpid.test.unit.client.message.ObjectMessageTest
    [junit] Tests run: 10, Failures: 0, Errors: 0, Time elapsed: 0.625 sec
    [junit] Running org.apache.qpid.test.unit.client.protocol.AMQProtocolSessionTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.23 sec
    [junit] Running org.apache.qpid.test.unit.client.temporaryqueue.TemporaryQueueTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 0.194 sec
    [junit] Running org.apache.qpid.test.unit.close.JavaServerCloseRaceConditionTest
    [junit] Tests run: 0, Failures: 0, Errors: 0, Time elapsed: 0.001 sec
    [junit] Running org.apache.qpid.test.unit.close.MessageConsumerCloseTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.044 sec
    [junit] Running org.apache.qpid.test.unit.close.MessageRequeueTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 16.502 sec
    [junit] Running org.apache.qpid.test.unit.close.TopicPublisherCloseTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 3.04 sec
    [junit] Running org.apache.qpid.test.unit.ct.DurableSubscriberTest
    [junit] Tests run: 0, Failures: 0, Errors: 0, Time elapsed: 0.001 sec
    [junit] Running org.apache.qpid.test.unit.message.JMSPropertiesTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.091 sec
    [junit] Running org.apache.qpid.test.unit.message.StreamMessageTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.117 sec
    [junit] Running org.apache.qpid.test.unit.message.UTF8Test
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.092 sec
    [junit] Running org.apache.qpid.test.unit.topic.DurableSubscriptionTest
    [junit] Tests run: 17, Failures: 0, Errors: 0, Time elapsed: 28.673 sec
    [junit] Running org.apache.qpid.test.unit.topic.TemporaryTopicTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.239 sec
    [junit] Running org.apache.qpid.test.unit.topic.TopicPublisherTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.039 sec
    [junit] Running org.apache.qpid.test.unit.topic.TopicSessionTest
    [junit] Tests run: 9, Failures: 0, Errors: 0, Time elapsed: 9.878 sec
    [junit] Running org.apache.qpid.test.unit.transacted.CommitRollbackTest
    [junit] Tests run: 12, Failures: 0, Errors: 0, Time elapsed: 15.806 sec
    [junit] Running org.apache.qpid.test.unit.transacted.TransactedTest
    [junit] Tests run: 7, Failures: 0, Errors: 0, Time elapsed: 7.974 sec
    [junit] Running org.apache.qpid.test.unit.transacted.TransactionTimeoutDisabledTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 3.64 sec
    [junit] Running org.apache.qpid.test.unit.transacted.TransactionTimeoutTest
    [junit] Tests run: 15, Failures: 0, Errors: 0, Time elapsed: 42.842 sec
    [junit] Running org.apache.qpid.test.unit.xa.FaultTest
    [junit] Tests run: 10, Failures: 0, Errors: 0, Time elapsed: 12.168 sec
    [junit] Running org.apache.qpid.test.unit.xa.QueueTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 1.062 sec
    [junit] Running org.apache.qpid.test.unit.xa.TopicTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 4.309 sec
    [junit] Running org.apache.qpid.test.utils.BrokerCommandHelperTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.035 sec
    [junit] Running org.apache.qpid.util.LogMonitorTest
    [junit] Tests run: 9, Failures: 0, Errors: 0, Time elapsed: 2.064 sec
    [junit] Tests FAILED
     [echo] Running ant for module : systests

touch-failed:
    [touch] Creating /x1/jenkins/jenkins-slave/workspace/Qpid-Java-Java-Test-IBMJDK1.6/trunk/qpid/java/build/results/systests/FAILED
    [touch] Creating /x1/jenkins/jenkins-slave/workspace/Qpid-Java-Java-Test-IBMJDK1.6/trunk/qpid/java/build/results/FAILED
     [echo] Running ant for module : perftests

prepare:

precompile:

compile:
     [echo] Targeting : 1.6

copy-extra-resources:

copy-resources:
     [echo] Copying resources from /x1/jenkins/jenkins-slave/workspace/Qpid-Java-Java-Test-IBMJDK1.6/trunk/qpid/java/perftests/src/main/resources to /x1/jenkins/jenkins-slave/workspace/Qpid-Java-Java-Test-IBMJDK1.6/trunk/qpid/java/build/scratch/perftests/classes...

copy-project-resources-metainf:

copy-module-resources-metainf:

copy-module-src-resources-metainf:

copy-files-to-module-metainf:

jar.manifest:

jar.nomanifest:

jar:

precompile-tests:

compile-tests:

copy-test-resources:

jar-tests:

jar-sources:

libs:

copy-bin:

copy-etc:

postbuild:

copy-broker-plugin-jars-deps:

copy-broker-plugin-jars:

build:

test:
     [echo] Using profile:java-mms.0-10
    [junit] Running org.apache.qpid.disttest.ArgumentParserTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.05 sec
    [junit] Running org.apache.qpid.disttest.ConfigFileHelperTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.016 sec
    [junit] Running org.apache.qpid.disttest.ResultsFileWriterTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.046 sec
    [junit] Running org.apache.qpid.disttest.VisitorTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.022 sec
    [junit] Running org.apache.qpid.disttest.client.ClientCommandVisitorTest
    [junit] Tests run: 8, Failures: 0, Errors: 0, Time elapsed: 0.119 sec
    [junit] Running org.apache.qpid.disttest.client.ClientTest
    [junit] Tests run: 8, Failures: 0, Errors: 0, Time elapsed: 0.592 sec
    [junit] Running org.apache.qpid.disttest.client.ConsumerParticipantTest
    [junit] Tests run: 7, Failures: 0, Errors: 0, Time elapsed: 0.258 sec
    [junit] Running org.apache.qpid.disttest.client.MessageProviderTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.171 sec
    [junit] Running org.apache.qpid.disttest.client.ParticipantExecutorTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 0.038 sec
    [junit] Running org.apache.qpid.disttest.client.ParticipantRegistryTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.036 sec
    [junit] Running org.apache.qpid.disttest.client.ParticipantResultFactoryTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.015 sec
    [junit] Running org.apache.qpid.disttest.client.ProducerParticipantTest
    [junit] Tests run: 9, Failures: 0, Errors: 0, Time elapsed: 1.803 sec
    [junit] Running org.apache.qpid.disttest.client.property.ListPropertyValueTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.028 sec
    [junit] Running org.apache.qpid.disttest.client.property.PropertyValueFactoryTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.033 sec
    [junit] Running org.apache.qpid.disttest.client.property.RandomPropertyValueTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.032 sec
    [junit] Running org.apache.qpid.disttest.client.property.RangePropertyValueTest
    [junit] Tests run: 8, Failures: 0, Errors: 0, Time elapsed: 0.053 sec
    [junit] Running org.apache.qpid.disttest.client.property.SimplePropertyValueTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.002 sec
    [junit] Running org.apache.qpid.disttest.client.utils.ExecutorWithNoLimitsTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.017 sec
    [junit] Running org.apache.qpid.disttest.client.utils.ExecutorWithTimeLimitTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 0.523 sec
    [junit] Running org.apache.qpid.disttest.controller.ClientRegistryTest
    [junit] Tests run: 8, Failures: 0, Errors: 0, Time elapsed: 2.58 sec
    [junit] Running org.apache.qpid.disttest.controller.ControllerTest
    [junit] Tests run: 6, Failures: 0, Errors: 0, Time elapsed: 0.117 sec
    [junit] Running org.apache.qpid.disttest.controller.ParticipatingClientsTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.028 sec
    [junit] Running org.apache.qpid.disttest.controller.TestRunnerTest
    [junit] Tests run: 6, Failures: 0, Errors: 0, Time elapsed: 1.209 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ClientConfigTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 0.021 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ConfigReaderTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.537 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ConfigTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.004 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ConnectionConfigTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.021 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ConsumerConfigTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.01 sec
    [junit] Running org.apache.qpid.disttest.controller.config.IterationValueTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.025 sec
    [junit] Running org.apache.qpid.disttest.controller.config.JavaScriptConfigEvaluatorTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.188 sec
    [junit] Running org.apache.qpid.disttest.controller.config.MessageProviderConfigTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.007 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ParticipantConfigTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.007 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ProducerConfigTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.014 sec
    [junit] Running org.apache.qpid.disttest.controller.config.SessionConfigTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.023 sec
    [junit] Running org.apache.qpid.disttest.controller.config.TestConfigTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.033 sec
    [junit] Running org.apache.qpid.disttest.controller.config.TestInstanceTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.012 sec
    [junit] Running org.apache.qpid.disttest.db.ResultsDbWriterTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 7.913 sec
    [junit] Running org.apache.qpid.disttest.jms.JmsMessageAdaptorTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.009 sec
    [junit] Running org.apache.qpid.disttest.message.JsonHandlerTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.021 sec
    [junit] Running org.apache.qpid.disttest.message.ParticipantResultTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.076 sec
    [junit] Running org.apache.qpid.disttest.results.aggregation.AggregatorTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.006 sec
    [junit] Running org.apache.qpid.disttest.results.aggregation.ParticipantResultAggregatorTest
    [junit] Tests run: 14, Failures: 0, Errors: 0, Time elapsed: 0.09 sec
    [junit] Running org.apache.qpid.disttest.results.aggregation.SeriesStatisticsTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.003 sec
    [junit] Running org.apache.qpid.disttest.results.aggregation.TestResultAggregatorTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 0.027 sec
    [junit] Running org.apache.qpid.disttest.results.formatting.CSVFormatterTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.004 sec
    [junit] Running org.apache.qpid.disttest.results.formatting.CSVOrderParticipantResultComparatorTest
    [junit] Tests run: 6, Failures: 0, Errors: 0, Time elapsed: 0.032 sec
    [junit] Running org.apache.qpid.systest.disttest.QpidQueueCreatorTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 1.237 sec
    [junit] Running org.apache.qpid.systest.disttest.clientonly.BasicDistributedClientTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.714 sec
    [junit] Running org.apache.qpid.systest.disttest.clientonly.ConsumerParticipantTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 6.42 sec
    [junit] Running org.apache.qpid.systest.disttest.clientonly.DistributedClientTest
    [junit] Tests run: 9, Failures: 0, Errors: 0, Time elapsed: 1.043 sec
    [junit] Running org.apache.qpid.systest.disttest.clientonly.MessageProviderTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.19 sec
    [junit] Running org.apache.qpid.systest.disttest.clientonly.ProducerParticipantTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.581 sec
    [junit] Running org.apache.qpid.systest.disttest.controllerandclient.ControllerAndClientTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 1.984 sec
    [junit] Running org.apache.qpid.systest.disttest.controlleronly.DistributedControllerTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 1.095 sec
    [junit] Running org.apache.qpid.systest.disttest.endtoend.EndToEndTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.372 sec
     [echo] Running ant for module : perftests

touch-failed:

BUILD FAILED
/x1/jenkins/jenkins-slave/workspace/Qpid-Java-Java-Test-IBMJDK1.6/trunk/qpid/java/build.xml:107: TEST SUITE FAILED

Total time: 20 minutes 1 second
Build step 'Invoke Ant' marked build as failure
[locks-and-latches] Releasing all the locks
[locks-and-latches] All the locks released
Recording test results

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

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


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

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

Changes:

[rgodfrey] QPID-5504 : remove unused inner classes

[rgodfrey] QPID-5504 : fix bug in DistributedTransaction when enqueuing a single message - brought to light by earlier refactoring

------------------------------------------
[...truncated 4988 lines...]
    [junit] Tests run: 6, Failures: 0, Errors: 0, Time elapsed: 0.787 sec
    [junit] Running org.apache.qpid.test.unit.client.MaxDeliveryCountTest
    [junit] Tests run: 7, Failures: 0, Errors: 0, Time elapsed: 3.65 sec
    [junit] Running org.apache.qpid.test.unit.client.QueueSessionFactoryTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.132 sec
    [junit] Running org.apache.qpid.test.unit.client.TopicSessionFactoryTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 0.158 sec
    [junit] Running org.apache.qpid.test.unit.client.channelclose.CloseWithBlockingReceiveTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 1.031 sec
    [junit] Running org.apache.qpid.test.unit.client.connection.BrokerClosesClientConnectionTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 12.101 sec
    [junit] Running org.apache.qpid.test.unit.client.connection.ConnectionFactoryTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.11 sec
    [junit] Running org.apache.qpid.test.unit.client.connection.ConnectionStartTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.067 sec
    [junit] Running org.apache.qpid.test.unit.client.connection.ConnectionTest
    [junit] Tests run: 12, Failures: 0, Errors: 0, Time elapsed: 0.422 sec
    [junit] Running org.apache.qpid.test.unit.client.connection.ExceptionListenerTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.079 sec
    [junit] Running org.apache.qpid.test.unit.client.message.ObjectMessageTest
    [junit] Tests run: 10, Failures: 0, Errors: 0, Time elapsed: 0.341 sec
    [junit] Running org.apache.qpid.test.unit.client.protocol.AMQProtocolSessionTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.16 sec
    [junit] Running org.apache.qpid.test.unit.client.temporaryqueue.TemporaryQueueTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 0.149 sec
    [junit] Running org.apache.qpid.test.unit.close.JavaServerCloseRaceConditionTest
    [junit] Tests run: 0, Failures: 0, Errors: 0, Time elapsed: 0.001 sec
    [junit] Running org.apache.qpid.test.unit.close.MessageConsumerCloseTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.036 sec
    [junit] Running org.apache.qpid.test.unit.close.MessageRequeueTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 16.39 sec
    [junit] Running org.apache.qpid.test.unit.close.TopicPublisherCloseTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 3.031 sec
    [junit] Running org.apache.qpid.test.unit.ct.DurableSubscriberTest
    [junit] Tests run: 0, Failures: 0, Errors: 0, Time elapsed: 0.001 sec
    [junit] Running org.apache.qpid.test.unit.message.JMSPropertiesTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.077 sec
    [junit] Running org.apache.qpid.test.unit.message.StreamMessageTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.068 sec
    [junit] Running org.apache.qpid.test.unit.message.UTF8Test
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.089 sec
    [junit] Running org.apache.qpid.test.unit.topic.DurableSubscriptionTest
    [junit] Tests run: 17, Failures: 0, Errors: 0, Time elapsed: 28.391 sec
    [junit] Running org.apache.qpid.test.unit.topic.TemporaryTopicTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.194 sec
    [junit] Running org.apache.qpid.test.unit.topic.TopicPublisherTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.032 sec
    [junit] Running org.apache.qpid.test.unit.topic.TopicSessionTest
    [junit] Tests run: 9, Failures: 0, Errors: 0, Time elapsed: 9.772 sec
    [junit] Running org.apache.qpid.test.unit.transacted.CommitRollbackTest
    [junit] Tests run: 12, Failures: 0, Errors: 0, Time elapsed: 15.522 sec
    [junit] Running org.apache.qpid.test.unit.transacted.TransactedTest
    [junit] Tests run: 7, Failures: 0, Errors: 0, Time elapsed: 7.865 sec
    [junit] Running org.apache.qpid.test.unit.transacted.TransactionTimeoutDisabledTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 3.598 sec
    [junit] Running org.apache.qpid.test.unit.transacted.TransactionTimeoutTest
    [junit] Tests run: 15, Failures: 0, Errors: 0, Time elapsed: 42.626 sec
    [junit] Running org.apache.qpid.test.unit.xa.FaultTest
    [junit] Tests run: 10, Failures: 0, Errors: 0, Time elapsed: 11.903 sec
    [junit] Running org.apache.qpid.test.unit.xa.QueueTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 1.047 sec
    [junit] Running org.apache.qpid.test.unit.xa.TopicTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 4.207 sec
    [junit] Running org.apache.qpid.test.utils.BrokerCommandHelperTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.019 sec
    [junit] Running org.apache.qpid.util.LogMonitorTest
    [junit] Tests run: 9, Failures: 0, Errors: 0, Time elapsed: 2.062 sec
    [junit] Tests FAILED
     [echo] Running ant for module : systests

touch-failed:
    [touch] Creating <https://builds.apache.org/job/Qpid-Java-Java-Test-IBMJDK1.6/ws/trunk/qpid/java/build/results/systests/FAILED>
    [touch] Creating <https://builds.apache.org/job/Qpid-Java-Java-Test-IBMJDK1.6/ws/trunk/qpid/java/build/results/FAILED>
     [echo] Running ant for module : perftests

prepare:

precompile:

compile:
     [echo] Targeting : 1.6

copy-extra-resources:

copy-resources:
     [echo] Copying resources from <https://builds.apache.org/job/Qpid-Java-Java-Test-IBMJDK1.6/ws/trunk/qpid/java/perftests/src/main/resources> to <https://builds.apache.org/job/Qpid-Java-Java-Test-IBMJDK1.6/ws/trunk/qpid/java/build/scratch/perftests/classes...>

copy-project-resources-metainf:

copy-module-resources-metainf:

copy-module-src-resources-metainf:

copy-files-to-module-metainf:

jar.manifest:

jar.nomanifest:

jar:

precompile-tests:

compile-tests:

copy-test-resources:

jar-tests:

jar-sources:

libs:

copy-bin:

copy-etc:

postbuild:

copy-broker-plugin-jars-deps:

copy-broker-plugin-jars:

build:

test:
     [echo] Using profile:java-mms.0-10
    [junit] Running org.apache.qpid.disttest.ArgumentParserTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.041 sec
    [junit] Running org.apache.qpid.disttest.ConfigFileHelperTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.02 sec
    [junit] Running org.apache.qpid.disttest.ResultsFileWriterTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.046 sec
    [junit] Running org.apache.qpid.disttest.VisitorTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.017 sec
    [junit] Running org.apache.qpid.disttest.client.ClientCommandVisitorTest
    [junit] Tests run: 8, Failures: 0, Errors: 0, Time elapsed: 0.104 sec
    [junit] Running org.apache.qpid.disttest.client.ClientTest
    [junit] Tests run: 8, Failures: 0, Errors: 0, Time elapsed: 0.572 sec
    [junit] Running org.apache.qpid.disttest.client.ConsumerParticipantTest
    [junit] Tests run: 7, Failures: 0, Errors: 0, Time elapsed: 0.198 sec
    [junit] Running org.apache.qpid.disttest.client.MessageProviderTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.106 sec
    [junit] Running org.apache.qpid.disttest.client.ParticipantExecutorTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 0.028 sec
    [junit] Running org.apache.qpid.disttest.client.ParticipantRegistryTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.004 sec
    [junit] Running org.apache.qpid.disttest.client.ParticipantResultFactoryTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.004 sec
    [junit] Running org.apache.qpid.disttest.client.ProducerParticipantTest
    [junit] Tests run: 9, Failures: 0, Errors: 0, Time elapsed: 1.979 sec
    [junit] Running org.apache.qpid.disttest.client.property.ListPropertyValueTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.003 sec
    [junit] Running org.apache.qpid.disttest.client.property.PropertyValueFactoryTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.005 sec
    [junit] Running org.apache.qpid.disttest.client.property.RandomPropertyValueTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.004 sec
    [junit] Running org.apache.qpid.disttest.client.property.RangePropertyValueTest
    [junit] Tests run: 8, Failures: 0, Errors: 0, Time elapsed: 0.005 sec
    [junit] Running org.apache.qpid.disttest.client.property.SimplePropertyValueTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.002 sec
    [junit] Running org.apache.qpid.disttest.client.utils.ExecutorWithNoLimitsTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.006 sec
    [junit] Running org.apache.qpid.disttest.client.utils.ExecutorWithTimeLimitTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 0.506 sec
    [junit] Running org.apache.qpid.disttest.controller.ClientRegistryTest
    [junit] Tests run: 8, Failures: 0, Errors: 0, Time elapsed: 2.557 sec
    [junit] Running org.apache.qpid.disttest.controller.ControllerTest
    [junit] Tests run: 6, Failures: 0, Errors: 0, Time elapsed: 0.054 sec
    [junit] Running org.apache.qpid.disttest.controller.ParticipatingClientsTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.009 sec
    [junit] Running org.apache.qpid.disttest.controller.TestRunnerTest
    [junit] Tests run: 6, Failures: 0, Errors: 0, Time elapsed: 1.126 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ClientConfigTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 0.008 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ConfigReaderTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.643 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ConfigTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.008 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ConnectionConfigTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.011 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ConsumerConfigTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.006 sec
    [junit] Running org.apache.qpid.disttest.controller.config.IterationValueTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.049 sec
    [junit] Running org.apache.qpid.disttest.controller.config.JavaScriptConfigEvaluatorTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.038 sec
    [junit] Running org.apache.qpid.disttest.controller.config.MessageProviderConfigTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.003 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ParticipantConfigTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.008 sec
    [junit] Running org.apache.qpid.disttest.controller.config.ProducerConfigTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.003 sec
    [junit] Running org.apache.qpid.disttest.controller.config.SessionConfigTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.014 sec
    [junit] Running org.apache.qpid.disttest.controller.config.TestConfigTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.007 sec
    [junit] Running org.apache.qpid.disttest.controller.config.TestInstanceTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.007 sec
    [junit] Running org.apache.qpid.disttest.db.ResultsDbWriterTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 1.154 sec
    [junit] Running org.apache.qpid.disttest.jms.JmsMessageAdaptorTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.003 sec
    [junit] Running org.apache.qpid.disttest.message.JsonHandlerTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.016 sec
    [junit] Running org.apache.qpid.disttest.message.ParticipantResultTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.045 sec
    [junit] Running org.apache.qpid.disttest.results.aggregation.AggregatorTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.008 sec
    [junit] Running org.apache.qpid.disttest.results.aggregation.ParticipantResultAggregatorTest
    [junit] Tests run: 14, Failures: 0, Errors: 0, Time elapsed: 0.005 sec
    [junit] Running org.apache.qpid.disttest.results.aggregation.SeriesStatisticsTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.002 sec
    [junit] Running org.apache.qpid.disttest.results.aggregation.TestResultAggregatorTest
    [junit] Tests run: 4, Failures: 0, Errors: 0, Time elapsed: 0.004 sec
    [junit] Running org.apache.qpid.disttest.results.formatting.CSVFormatterTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.003 sec
    [junit] Running org.apache.qpid.disttest.results.formatting.CSVOrderParticipantResultComparatorTest
    [junit] Tests run: 6, Failures: 0, Errors: 0, Time elapsed: 0.035 sec
    [junit] Running org.apache.qpid.systest.disttest.QpidQueueCreatorTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 1.256 sec
    [junit] Running org.apache.qpid.systest.disttest.clientonly.BasicDistributedClientTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 0.894 sec
    [junit] Running org.apache.qpid.systest.disttest.clientonly.ConsumerParticipantTest
    [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 6.315 sec
    [junit] Running org.apache.qpid.systest.disttest.clientonly.DistributedClientTest
    [junit] Tests run: 9, Failures: 0, Errors: 0, Time elapsed: 0.862 sec
    [junit] Running org.apache.qpid.systest.disttest.clientonly.MessageProviderTest
    [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.138 sec
    [junit] Running org.apache.qpid.systest.disttest.clientonly.ProducerParticipantTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.583 sec
    [junit] Running org.apache.qpid.systest.disttest.controllerandclient.ControllerAndClientTest
    [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 1.944 sec
    [junit] Running org.apache.qpid.systest.disttest.controlleronly.DistributedControllerTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 1.085 sec
    [junit] Running org.apache.qpid.systest.disttest.endtoend.EndToEndTest
    [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.274 sec
     [echo] Running ant for module : perftests

touch-failed:

BUILD FAILED
<https://builds.apache.org/job/Qpid-Java-Java-Test-IBMJDK1.6/ws/trunk/qpid/java/build.xml>:107: TEST SUITE FAILED

Total time: 15 minutes 41 seconds
Build step 'Invoke Ant' marked build as failure
[locks-and-latches] Releasing all the locks
[locks-and-latches] All the locks released
Recording test results