See <https://builds.apache.org/job/kafka-0.10.0-jdk7/210/display/redirect?page=changes>
Changes: [me] MINOR: Add serialized vagrant rsync until upstream fixes broken ------------------------------------------ [...truncated 76.42 KB...] at java.util.concurrent.FutureTask.run(FutureTask.java:266) at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142) at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617) at java.lang.Thread.run(Thread.java:745) kafka.admin.AddPartitionsTest > testManualAssignmentOfReplicas PASSED kafka.admin.TopicCommandTest > testCreateIfNotExists PASSED kafka.admin.TopicCommandTest > testCreateAlterTopicWithRackAware PASSED kafka.admin.TopicCommandTest > testTopicDeletion PASSED kafka.admin.TopicCommandTest > testConfigPreservationAcrossPartitionAlteration PASSED kafka.admin.TopicCommandTest > testAlterIfExists PASSED kafka.admin.TopicCommandTest > testDeleteIfExists PASSED kafka.admin.ReassignPartitionsCommandTest > testRackAwareReassign PASSED kafka.admin.AdminTest > testBasicPreferredReplicaElection PASSED kafka.admin.AdminTest > testPreferredReplicaJsonData PASSED kafka.admin.AdminTest > testReassigningNonExistingPartition PASSED kafka.admin.AdminTest > testGetBrokerMetadatas PASSED kafka.admin.AdminTest > testBootstrapClientIdConfig PASSED kafka.admin.AdminTest > testPartitionReassignmentNonOverlappingReplicas PASSED kafka.admin.AdminTest > testReplicaAssignment PASSED kafka.admin.AdminTest > testPartitionReassignmentWithLeaderNotInNewReplicas PASSED kafka.admin.AdminTest > testTopicConfigChange PASSED kafka.admin.AdminTest > testResumePartitionReassignmentThatWasCompleted PASSED kafka.admin.AdminTest > testManualReplicaAssignment PASSED kafka.admin.AdminTest > testPartitionReassignmentWithLeaderInNewReplicas PASSED kafka.admin.AdminTest > testShutdownBroker PASSED kafka.admin.AdminTest > testTopicCreationWithCollision PASSED kafka.admin.AdminTest > testTopicCreationInZK PASSED kafka.network.SocketServerTest > testClientDisconnectionUpdatesRequestMetrics PASSED kafka.network.SocketServerTest > testMaxConnectionsPerIp PASSED kafka.network.SocketServerTest > testBrokerSendAfterChannelClosedUpdatesRequestMetrics PASSED kafka.network.SocketServerTest > simpleRequest PASSED kafka.network.SocketServerTest > testSessionPrincipal PASSED kafka.network.SocketServerTest > testMaxConnectionsPerIpOverrides PASSED kafka.network.SocketServerTest > testSocketsCloseOnShutdown FAILED org.scalatest.junit.JUnitTestFailedError: expected exception when writing to closed trace socket at org.scalatest.junit.AssertionsForJUnit$class.newAssertionFailedException(AssertionsForJUnit.scala:102) at org.scalatest.junit.JUnitSuite.newAssertionFailedException(JUnitSuite.scala:79) at org.scalatest.Assertions$class.fail(Assertions.scala:1328) at org.scalatest.junit.JUnitSuite.fail(JUnitSuite.scala:79) at kafka.network.SocketServerTest.testSocketsCloseOnShutdown(SocketServerTest.scala:194) kafka.network.SocketServerTest > testSslSocketServer PASSED kafka.network.SocketServerTest > tooBigRequestIsRejected PASSED kafka.consumer.ZookeeperConsumerConnectorTest > testBasic PASSED kafka.consumer.ZookeeperConsumerConnectorTest > testCompressionSetConsumption PASSED kafka.consumer.ZookeeperConsumerConnectorTest > testLeaderSelectionForPartition PASSED kafka.consumer.ZookeeperConsumerConnectorTest > testConsumerDecoder PASSED kafka.consumer.ZookeeperConsumerConnectorTest > testConsumerRebalanceListener PASSED kafka.consumer.ZookeeperConsumerConnectorTest > testCompression PASSED kafka.consumer.PartitionAssignorTest > testRoundRobinPartitionAssignor PASSED kafka.consumer.PartitionAssignorTest > testRangePartitionAssignor PASSED kafka.consumer.TopicFilterTest > testWhitelists PASSED kafka.consumer.TopicFilterTest > testWildcardTopicCountGetTopicCountMapEscapeJson PASSED kafka.consumer.TopicFilterTest > testBlacklists PASSED kafka.consumer.ConsumerIteratorTest > testConsumerIteratorDeduplicationDeepIterator PASSED kafka.consumer.ConsumerIteratorTest > testConsumerIteratorDecodingFailure PASSED kafka.metrics.KafkaTimerTest > testKafkaTimer PASSED kafka.metrics.MetricsTest > testMetricsReporterAfterDeletingTopic PASSED kafka.metrics.MetricsTest > testBrokerTopicMetricsUnregisteredAfterDeletingTopic PASSED kafka.metrics.MetricsTest > testMetricsLeak PASSED kafka.utils.timer.TimerTest > testAlreadyExpiredTask PASSED kafka.utils.timer.TimerTest > testTaskExpiration PASSED kafka.utils.timer.TimerTaskListTest > testAll PASSED kafka.utils.CommandLineUtilsTest > testParseEmptyArg PASSED kafka.utils.CommandLineUtilsTest > testParseSingleArg PASSED kafka.utils.CommandLineUtilsTest > testParseArgs PASSED kafka.utils.CommandLineUtilsTest > testParseEmptyArgAsValid PASSED kafka.utils.ReplicationUtilsTest > testUpdateLeaderAndIsr PASSED kafka.utils.ReplicationUtilsTest > testGetLeaderIsrAndEpochForPartition PASSED kafka.utils.JsonTest > testJsonEncoding PASSED kafka.utils.SchedulerTest > testMockSchedulerNonPeriodicTask PASSED kafka.utils.SchedulerTest > testMockSchedulerPeriodicTask PASSED kafka.utils.SchedulerTest > testNonPeriodicTask PASSED kafka.utils.SchedulerTest > testRestart PASSED kafka.utils.SchedulerTest > testReentrantTaskInMockScheduler PASSED kafka.utils.SchedulerTest > testPeriodicTask PASSED kafka.utils.ZkUtilsTest > testAbortedConditionalDeletePath PASSED kafka.utils.ZkUtilsTest > testSuccessfulConditionalDeletePath PASSED kafka.utils.IteratorTemplateTest > testIterator PASSED kafka.utils.UtilsTest > testAbs PASSED kafka.utils.UtilsTest > testReplaceSuffix PASSED kafka.utils.UtilsTest > testCircularIterator PASSED kafka.utils.UtilsTest > testReadBytes PASSED kafka.utils.UtilsTest > testCsvList PASSED kafka.utils.UtilsTest > testReadInt PASSED kafka.utils.UtilsTest > testCsvMap PASSED kafka.utils.UtilsTest > testInLock PASSED kafka.utils.UtilsTest > testSwallow PASSED kafka.utils.ByteBoundedBlockingQueueTest > testByteBoundedBlockingQueue PASSED kafka.producer.AsyncProducerTest > testFailedSendRetryLogic PASSED kafka.producer.AsyncProducerTest > testQueueTimeExpired PASSED kafka.producer.AsyncProducerTest > testPartitionAndCollateEvents PASSED kafka.producer.AsyncProducerTest > testBatchSize PASSED kafka.producer.AsyncProducerTest > testSerializeEvents PASSED kafka.producer.AsyncProducerTest > testProducerQueueSize PASSED kafka.producer.AsyncProducerTest > testRandomPartitioner PASSED kafka.producer.AsyncProducerTest > testInvalidConfiguration PASSED kafka.producer.AsyncProducerTest > testInvalidPartition PASSED kafka.producer.AsyncProducerTest > testNoBroker PASSED kafka.producer.AsyncProducerTest > testProduceAfterClosed PASSED kafka.producer.AsyncProducerTest > testJavaProducer PASSED kafka.producer.AsyncProducerTest > testIncompatibleEncoder PASSED kafka.producer.SyncProducerTest > testReachableServer PASSED kafka.producer.SyncProducerTest > testMessageSizeTooLarge PASSED kafka.producer.SyncProducerTest > testNotEnoughReplicas PASSED kafka.producer.SyncProducerTest > testMessageSizeTooLargeWithAckZero PASSED kafka.producer.SyncProducerTest > testProducerCanTimeout PASSED kafka.producer.SyncProducerTest > testProduceRequestWithNoResponse PASSED kafka.producer.SyncProducerTest > testEmptyProduceRequest PASSED kafka.producer.SyncProducerTest > testProduceCorrectlyReceivesResponse PASSED kafka.producer.ProducerTest > testSendToNewTopic PASSED kafka.producer.ProducerTest > testAsyncSendCanCorrectlyFailWithTimeout PASSED kafka.producer.ProducerTest > testSendNullMessage PASSED kafka.producer.ProducerTest > testUpdateBrokerPartitionInfo PASSED kafka.producer.ProducerTest > testSendWithDeadBroker PASSED integration.kafka.api.GroupCoordinatorIntegrationTest > testGroupCoordinatorPropagatesOfffsetsTopicCompressionCodec PASSED unit.kafka.server.ApiVersionsTest > testApiVersions PASSED unit.kafka.admin.ReassignPartitionsClusterTest > shouldExpandCluster PASSED unit.kafka.admin.ReassignPartitionsClusterTest > shouldMoveSinglePartition PASSED unit.kafka.admin.ReassignPartitionsClusterTest > shouldShrinkCluster PASSED 798 tests completed, 1 failed :kafka-0.10.0-jdk7:core:test FAILED :test_core_2_10 FAILED FAILURE: Build failed with an exception. * What went wrong: Execution failed for task ':core:test'. > There were failing tests. See the report at: > file://<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/build/reports/tests/index.html> * Try: Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. BUILD FAILED Total time: 36 mins 25.857 secs Build step 'Execute shell' marked build as failure Recording test results Setting GRADLE_2_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.4-rc-2 Setting GRADLE_2_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.4-rc-2