See <https://builds.apache.org/job/Kafka-trunk/206/changes>
Changes: [jay.kreps] KAFKA-1326 Refactor Sender to support consumer. ------------------------------------------ [...truncated 949 lines...] kafka.log.LogTest > testAsyncDelete PASSED kafka.log.LogTest > testOpenDeletesObsoleteFiles PASSED kafka.log.LogTest > testAppendMessageWithNullPayload PASSED kafka.log.LogTest > testCorruptLog PASSED kafka.log.LogTest > testCleanShutdownFile PASSED kafka.log.OffsetMapTest > testBasicValidation PASSED kafka.log.OffsetMapTest > testClear PASSED kafka.server.ReplicaFetchTest > testReplicaFetcherThread PASSED kafka.server.RequestPurgatoryTest > testRequestSatisfaction PASSED kafka.server.RequestPurgatoryTest > testRequestExpiry PASSED kafka.server.LogOffsetTest > testGetOffsetsForUnknownTopic PASSED kafka.server.LogOffsetTest > testGetOffsetsBeforeLatestTime PASSED kafka.server.LogOffsetTest > testEmptyLogsGetOffsets PASSED kafka.server.LogOffsetTest > testGetOffsetsBeforeNow PASSED kafka.server.LogOffsetTest > testGetOffsetsBeforeEarliestTime PASSED kafka.server.SimpleFetchTest > testNonReplicaSeesHwWhenFetching PASSED kafka.server.SimpleFetchTest > testReplicaSeesLeoWhenFetching PASSED kafka.server.ServerShutdownTest > testCleanShutdown PASSED kafka.server.ServerShutdownTest > testCleanShutdownWithDeleteTopicEnabled PASSED kafka.server.LogRecoveryTest > testHWCheckpointNoFailuresSingleLogSegment PASSED kafka.server.LogRecoveryTest > testHWCheckpointWithFailuresSingleLogSegment PASSED kafka.server.LogRecoveryTest > testHWCheckpointNoFailuresMultipleLogSegments PASSED kafka.server.LogRecoveryTest > testHWCheckpointWithFailuresMultipleLogSegments PASSED kafka.server.OffsetCommitTest > testUpdateOffsets PASSED kafka.server.OffsetCommitTest > testCommitAndFetchOffsets PASSED kafka.server.OffsetCommitTest > testLargeMetadataPayload PASSED kafka.server.KafkaConfigTest > testLogRetentionTimeHoursProvided PASSED kafka.server.KafkaConfigTest > testLogRetentionTimeMinutesProvided PASSED kafka.server.KafkaConfigTest > testLogRetentionTimeNoConfigProvided PASSED kafka.server.KafkaConfigTest > testLogRetentionTimeBothMinutesAndHoursProvided PASSED kafka.server.KafkaConfigTest > testAdvertiseDefaults PASSED kafka.server.KafkaConfigTest > testAdvertiseConfigured PASSED kafka.server.KafkaConfigTest > testUncleanLeaderElectionDefault PASSED kafka.server.KafkaConfigTest > testUncleanElectionDisabled PASSED kafka.server.KafkaConfigTest > testUncleanElectionEnabled PASSED kafka.server.KafkaConfigTest > testUncleanElectionInvalid PASSED kafka.server.AdvertiseBrokerTest > testBrokerAdvertiseToZK PASSED kafka.server.DynamicConfigChangeTest > testConfigChange PASSED kafka.server.DynamicConfigChangeTest > testConfigChangeOnNonExistingTopic PASSED kafka.server.HighwatermarkPersistenceTest > testHighWatermarkPersistenceSinglePartition PASSED kafka.server.HighwatermarkPersistenceTest > testHighWatermarkPersistenceMultiplePartitions PASSED kafka.server.IsrExpirationTest > testIsrExpirationForStuckFollowers PASSED kafka.server.IsrExpirationTest > testIsrExpirationForSlowFollowers PASSED kafka.server.ReplicaManagerTest > testHighWaterMarkDirectoryMapping PASSED kafka.server.ReplicaManagerTest > testHighwaterMarkRelativeDirectoryMapping PASSED kafka.server.LeaderElectionTest > testLeaderElectionAndEpoch PASSED kafka.server.LeaderElectionTest > testLeaderElectionWithStaleControllerEpoch PASSED kafka.metrics.KafkaTimerTest > testKafkaTimer PASSED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabled PASSED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionDisabled PASSED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabledByTopicOverride PASSED kafka.integration.UncleanLeaderElectionTest > testCleanLeaderElectionDisabledByTopicOverride PASSED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionInvalidTopicOverride PASSED kafka.integration.PrimitiveApiTest > testFetchRequestCanProperlySerialize PASSED kafka.integration.PrimitiveApiTest > testEmptyFetchRequest PASSED kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetch PASSED kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetchWithCompression PASSED kafka.integration.PrimitiveApiTest > testProduceAndMultiFetch PASSED kafka.integration.PrimitiveApiTest > testMultiProduce PASSED kafka.integration.PrimitiveApiTest > testConsumerEmptyTopic PASSED kafka.integration.PrimitiveApiTest > testPipelinedProduceRequests PASSED kafka.integration.TopicMetadataTest > testAutoCreateTopic PASSED kafka.integration.TopicMetadataTest > testTopicMetadataRequest PASSED kafka.integration.TopicMetadataTest > testBasicTopicMetadata PASSED kafka.integration.TopicMetadataTest > testGetAllTopicMetadata PASSED kafka.integration.RollingBounceTest > testRollingBounce PASSED kafka.integration.FetcherTest > testFetcher PASSED kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooHigh PASSED kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooLow PASSED kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooHigh PASSED kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooLow PASSED kafka.consumer.ConsumerIteratorTest > testConsumerIteratorDeduplicationDeepIterator PASSED kafka.consumer.ConsumerIteratorTest > testConsumerIteratorDecodingFailure PASSED kafka.consumer.TopicFilterTest > testWhitelists PASSED kafka.consumer.TopicFilterTest > testBlacklists PASSED kafka.consumer.ZookeeperConsumerConnectorTest > testBasic PASSED kafka.consumer.ZookeeperConsumerConnectorTest > testCompression PASSED kafka.consumer.ZookeeperConsumerConnectorTest > testCompressionSetConsumption PASSED kafka.consumer.ZookeeperConsumerConnectorTest > testConsumerDecoder PASSED kafka.consumer.ZookeeperConsumerConnectorTest > testLeaderSelectionForPartition PASSED kafka.network.SocketServerTest > simpleRequest PASSED kafka.network.SocketServerTest > tooBigRequestIsRejected PASSED kafka.network.SocketServerTest > testNullResponse PASSED kafka.network.SocketServerTest > testSocketsCloseOnShutdown PASSED kafka.zk.ZKEphemeralTest > testEphemeralNodeCleanup PASSED kafka.admin.AddPartitionsTest > testTopicDoesNotExist PASSED kafka.admin.AddPartitionsTest > testWrongReplicaCount PASSED kafka.admin.AddPartitionsTest > testIncrementPartitions PASSED kafka.admin.AddPartitionsTest > testManualAssignmentOfReplicas PASSED kafka.admin.AddPartitionsTest > testReplicaPlacement PASSED kafka.admin.DeleteTopicTest > testDeleteTopicWithAllAliveReplicas PASSED kafka.admin.DeleteTopicTest > testResumeDeleteTopicWithRecoveredFollower PASSED kafka.admin.DeleteTopicTest > testResumeDeleteTopicOnControllerFailover PASSED kafka.admin.DeleteTopicTest > testPartitionReassignmentDuringDeleteTopic PASSED kafka.admin.DeleteTopicTest > testDeleteTopicDuringAddPartition FAILED junit.framework.AssertionFailedError: Admin path /admin/delete_topic/test path not deleted even after a replica is restarted at junit.framework.Assert.fail(Assert.java:47) at kafka.utils.TestUtils$.waitUntilTrue(TestUtils.scala:582) at kafka.admin.DeleteTopicTest.verifyTopicDeletion(DeleteTopicTest.scala:277) at kafka.admin.DeleteTopicTest.testDeleteTopicDuringAddPartition(DeleteTopicTest.scala:160) kafka.admin.DeleteTopicTest > testAddPartitionDuringDeleteTopic PASSED kafka.admin.DeleteTopicTest > testRecreateTopicAfterDeletion PASSED kafka.admin.DeleteTopicTest > testAutoCreateAfterDeleteTopic PASSED kafka.admin.DeleteTopicTest > testDeleteNonExistingTopic PASSED kafka.admin.AdminTest > testReplicaAssignment PASSED kafka.admin.AdminTest > testManualReplicaAssignment PASSED kafka.admin.AdminTest > testTopicCreationInZK PASSED kafka.admin.AdminTest > testPartitionReassignmentWithLeaderInNewReplicas PASSED kafka.admin.AdminTest > testPartitionReassignmentWithLeaderNotInNewReplicas PASSED kafka.admin.AdminTest > testPartitionReassignmentNonOverlappingReplicas PASSED kafka.admin.AdminTest > testReassigningNonExistingPartition PASSED kafka.admin.AdminTest > testResumePartitionReassignmentThatWasCompleted PASSED kafka.admin.AdminTest > testPreferredReplicaJsonData PASSED kafka.admin.AdminTest > testBasicPreferredReplicaElection PASSED kafka.admin.AdminTest > testShutdownBroker PASSED kafka.admin.AdminTest > testTopicConfigChange PASSED unit.kafka.common.TopicTest > testInvalidTopicNames PASSED unit.kafka.common.ConfigTest > testInvalidClientIds PASSED unit.kafka.common.ConfigTest > testInvalidGroupIds PASSED 259 tests completed, 1 failed :core:test 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:///home/hudson/jenkins-slave/workspace/Kafka-trunk/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: 6 mins 27.649 secs Build step 'Execute shell' marked build as failure