See <https://builds.apache.org/job/Kafka-trunk/603/changes>
Changes:
[wangguoz] KAFKA-2467: Fix changes to behavior in ConsoleConsumer: properly parse consumer.config
option, handle exceptions during message processing, and print number of processed messages
to stderr.
------------------------------------------
[...truncated 897 lines...]
kafka.utils.timer.TimerTest > testTaskExpiration PASSED
kafka.server.OffsetCommitTest > testUpdateOffsets PASSED
kafka.coordinator.ConsumerCoordinatorResponseTest > testHeartbeatUnknownGroup PASSED
kafka.api.ProducerSendTest > testCloseWithZeroTimeoutFromCallerThread PASSED
kafka.admin.DeleteConsumerGroupTest > testTopicWideDeleteInZK PASSED
kafka.coordinator.ConsumerCoordinatorResponseTest > testJoinGroupUnknownConsumerExistingGroup
PASSED
kafka.coordinator.ConsumerCoordinatorResponseTest > testJoinGroupSessionTimeoutTooSmall
PASSED
kafka.coordinator.ConsumerCoordinatorResponseTest > testHeartbeatIllegalGeneration PASSED
kafka.coordinator.ConsumerCoordinatorResponseTest > testGenerationIdIncrementsOnRebalance
PASSED
kafka.coordinator.ConsumerCoordinatorResponseTest > testHeartbeatUnknownConsumerExistingGroup
PASSED
kafka.integration.TopicMetadataTest > testIsrAfterBrokerShutDownAndJoinsBack PASSED
kafka.admin.AdminTest > testBasicPreferredReplicaElection PASSED
kafka.admin.DeleteTopicTest > testAddPartitionDuringDeleteTopic PASSED
kafka.admin.AddPartitionsTest > testWrongReplicaCount PASSED
kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooHigh PASSED
kafka.admin.DeleteConsumerGroupTest > testConsumptionOnRecreatedTopicAfterTopicWideDeleteInZK
PASSED
kafka.admin.DeleteTopicTest > testRecreateTopicAfterDeletion PASSED
kafka.admin.AdminTest > testShutdownBroker PASSED
kafka.admin.AdminTest > testReplicaAssignment PASSED
kafka.integration.FetcherTest > testFetcher PASSED
kafka.common.ConfigTest > testInvalidGroupIds PASSED
kafka.common.ConfigTest > testInvalidClientIds PASSED
kafka.admin.AdminTest > testTopicCreationWithCollision PASSED
kafka.api.ProducerSendTest > testCloseWithZeroTimeoutFromSenderThread PASSED
kafka.utils.SchedulerTest > testPeriodicTask PASSED
kafka.utils.SchedulerTest > testReentrantTaskInMockScheduler PASSED
kafka.utils.SchedulerTest > testMockSchedulerPeriodicTask PASSED
kafka.utils.SchedulerTest > testNonPeriodicTask PASSED
kafka.utils.SchedulerTest > testMockSchedulerNonPeriodicTask PASSED
kafka.utils.SchedulerTest > testRestart PASSED
kafka.api.ConsumerTest > testSimpleConsumption PASSED
kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooLow PASSED
kafka.admin.AdminTest > testTopicCreationInZK PASSED
kafka.admin.AddPartitionsTest > testIncrementPartitions PASSED
kafka.admin.DeleteTopicTest > testDeleteNonExistingTopic PASSED
kafka.admin.AdminTest > testTopicConfigChange PASSED
kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooHigh PASSED
kafka.log.LogTest > testCorruptLog PASSED
kafka.log.LogTest > testCleanShutdownFile PASSED
kafka.log.LogTest > testParseTopicPartitionName PASSED
kafka.log.LogTest > testParseTopicPartitionNameForEmptyName PASSED
kafka.log.LogTest > testParseTopicPartitionNameForNull PASSED
kafka.log.LogTest > testParseTopicPartitionNameForMissingSeparator PASSED
kafka.log.LogTest > testParseTopicPartitionNameForMissingTopic PASSED
kafka.log.LogTest > testParseTopicPartitionNameForMissingPartition PASSED
kafka.log.LogCleanerIntegrationTest > cleanerTest[0] PASSED
kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooLow PASSED
kafka.api.ConsumerTest > testCommitSpecifiedOffsets PASSED
kafka.api.ConsumerBounceTest > testConsumptionWithBrokerFailures PASSED
kafka.utils.IteratorTemplateTest > testIterator PASSED
kafka.api.ProducerFailureHandlingTest > testNoResponse PASSED
kafka.api.ConsumerTest > testPositionAndCommit PASSED
kafka.integration.RollingBounceTest > testRollingBounce PASSED
kafka.common.TopicTest > testTopicHasCollisionChars PASSED
kafka.common.TopicTest > testTopicHasCollision PASSED
kafka.common.TopicTest > testInvalidTopicNames PASSED
kafka.api.ProducerFailureHandlingTest > testInvalidPartition PASSED
kafka.api.ConsumerTest > testPartitionsFor PASSED
kafka.api.ProducerFailureHandlingTest > testSendAfterClosed PASSED
kafka.integration.UncleanLeaderElectionTest > testCleanLeaderElectionDisabledByTopicOverride
PASSED
kafka.admin.DeleteTopicTest > testDeleteTopicWithCleaner PASSED
kafka.api.ProducerFailureHandlingTest > testCannotSendToInternalTopic PASSED
kafka.api.ProducerFailureHandlingTest > testNotEnoughReplicas PASSED
kafka.api.ConsumerTest > testListTopics PASSED
kafka.admin.DeleteTopicTest > testDeleteTopicAlreadyMarkedAsDeleted PASSED
kafka.log.LogCleanerIntegrationTest > cleanerTest[1] PASSED
kafka.integration.PrimitiveApiTest > testEmptyFetchRequest PASSED
kafka.integration.PrimitiveApiTest > testConsumerEmptyTopic PASSED
kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabledByTopicOverride
PASSED
kafka.api.ConsumerTest > testPartitionReassignmentCallback PASSED
kafka.integration.PrimitiveApiTest > testPipelinedProduceRequests PASSED
kafka.integration.PrimitiveApiTest > testProduceAndMultiFetch PASSED
kafka.api.ConsumerTest > testUnsubscribeTopic PASSED
kafka.integration.PrimitiveApiTest > testMultiProduce PASSED
kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetch PASSED
kafka.api.ConsumerTest > testExpandingTopicSubscriptions PASSED
kafka.integration.PrimitiveApiTest > testFetchRequestCanProperlySerialize PASSED
kafka.api.ProducerFailureHandlingTest > testNotEnoughReplicasAfterBrokerShutdown PASSED
kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetchWithCompression
PASSED
kafka.log.LogCleanerIntegrationTest > cleanerTest[2] PASSED
kafka.api.ConsumerTest > testAutoOffsetReset PASSED
kafka.api.ProducerFailureHandlingTest > testTooLargeRecordWithAckZero PASSED
kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionDisabled PASSED
kafka.api.ProducerFailureHandlingTest > testTooLargeRecordWithAckOne PASSED
kafka.api.ConsumerTest > testSeek PASSED
kafka.api.ProducerFailureHandlingTest > testNonExistentTopic PASSED
kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabled PASSED
kafka.api.ConsumerTest > testGroupConsumption PASSED
kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionInvalidTopicOverride
PASSED
kafka.zk.ZKEphemeralTest > testEphemeralNodeCleanup PASSED
kafka.api.ProducerFailureHandlingTest > testWrongBrokerList PASSED
kafka.utils.ByteBoundedBlockingQueueTest > testByteBoundedBlockingQueue PASSED
kafka.api.ConsumerTest > testShrinkingTopicSubscriptions PASSED
kafka.log.LogCleanerIntegrationTest > cleanerTest[3] PASSED
kafka.api.ConsumerTest > testPartitionPauseAndResume PASSED
kafka.log.LogManagerTest > testCleanupExpiredSegments PASSED
kafka.log.LogManagerTest > testRecoveryDirectoryMappingWithTrailingSlash PASSED
kafka.api.SSLConsumerTest > testAutoOffsetReset PASSED
kafka.api.ConsumerTest > testPauseStateNotPreservedByRebalance PASSED
kafka.utils.CommandLineUtilsTest > testParseArgs PASSED
kafka.utils.CommandLineUtilsTest > testParseSingleArg PASSED
kafka.utils.CommandLineUtilsTest > testParseEmptyArg PASSED
kafka.api.SSLProducerSendTest > testSendOffset PASSED
kafka.api.SSLProducerSendTest > testClose PASSED
kafka.api.SSLConsumerTest > testSeek PASSED
kafka.api.SSLProducerSendTest > testSendToPartition PASSED
kafka.utils.ReplicationUtilsTest > testUpdateLeaderAndIsr PASSED
kafka.utils.ReplicationUtilsTest > testGetLeaderIsrAndEpochForPartition PASSED
kafka.api.SSLConsumerTest > testGroupConsumption PASSED
kafka.api.SSLConsumerTest > testPositionAndCommit PASSED
kafka.api.SSLConsumerTest > testPartitionsFor PASSED
kafka.api.SSLConsumerTest > testSimpleConsumption PASSED
kafka.message.MessageWriterTest > testWithNoCompressionAttribute PASSED
kafka.message.MessageWriterTest > testBufferingOutputStream PASSED
kafka.message.MessageWriterTest > testWithKey PASSED
kafka.message.MessageWriterTest > testWithCompressionAttribute PASSED
513 tests completed, 2 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:///x1/jenkins/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: 3 mins 55.291 secs
Build step 'Execute shell' marked build as failure
Setting GRADLE_2_1_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.1
|