Return-Path: X-Original-To: apmail-kafka-dev-archive@www.apache.org Delivered-To: apmail-kafka-dev-archive@www.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id D208418407 for ; Thu, 27 Aug 2015 01:14:28 +0000 (UTC) Received: (qmail 74020 invoked by uid 500); 27 Aug 2015 01:14:28 -0000 Delivered-To: apmail-kafka-dev-archive@kafka.apache.org Received: (qmail 73932 invoked by uid 500); 27 Aug 2015 01:14:28 -0000 Mailing-List: contact dev-help@kafka.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@kafka.apache.org Delivered-To: mailing list dev@kafka.apache.org Received: (qmail 73919 invoked by uid 99); 27 Aug 2015 01:14:28 -0000 Received: from crius.apache.org (HELO crius.apache.org) (140.211.11.14) by apache.org (qpsmtpd/0.29) with ESMTP; Thu, 27 Aug 2015 01:14:28 +0000 Received: from crius.apache.org (localhost [127.0.0.1]) by crius.apache.org (ASF Mail Server at crius.apache.org) with ESMTP id 29D6F9C0603; Thu, 27 Aug 2015 01:13:21 +0000 (UTC) Date: Thu, 27 Aug 2015 01:13:20 +0000 (UTC) From: Apache Jenkins Server To: dev@kafka.apache.org, junrao@gmail.com, wangguoz@gmail.com Message-ID: <694827565.594.1440638000597.JavaMail.jenkins@crius> In-Reply-To: <1363845691.536.1440631075802.JavaMail.jenkins@crius> References: <1363845691.536.1440631075802.JavaMail.jenkins@crius> Subject: Build failed in Jenkins: Kafka-trunk #602 MIME-Version: 1.0 Content-Type: text/plain; charset=UTF-8 Content-Transfer-Encoding: 7bit X-Jenkins-Job: Kafka-trunk X-Jenkins-Result: FAILURE See Changes: [wangguoz] KAFKA-2388: refactor KafkaConsumer subscribe API ------------------------------------------ [...truncated 1633 lines...] kafka.coordinator.ConsumerCoordinatorResponseTest > testHeartbeatIllegalGeneration PASSED kafka.admin.DeleteConsumerGroupTest > testTopicWideDeleteInZK PASSED kafka.coordinator.ConsumerCoordinatorResponseTest > testHeartbeatDuringRebalanceCausesIllegalGeneration PASSED kafka.coordinator.ConsumerCoordinatorResponseTest > testValidJoinGroup PASSED kafka.coordinator.ConsumerCoordinatorResponseTest > testHeartbeatUnknownConsumerExistingGroup PASSED kafka.coordinator.ConsumerCoordinatorResponseTest > testJoinGroupWrongCoordinator PASSED kafka.integration.TopicMetadataTest > testAliveBrokersListWithNoTopicsAfterNewBrokerStartup PASSED kafka.admin.AdminTest > testPartitionReassignmentWithLeaderNotInNewReplicas PASSED kafka.api.QuotasTest > testProducerConsumerOverrideUnthrottled PASSED kafka.utils.timer.TimerTaskListTest > testAll PASSED kafka.integration.TopicMetadataTest > testBasicTopicMetadata PASSED kafka.api.ConsumerTest > testPartitionPauseAndResume PASSED kafka.admin.DeleteTopicTest > testRecreateTopicAfterDeletion PASSED kafka.integration.TopicMetadataTest > testGetAllTopicMetadata PASSED kafka.api.ProducerBounceTest > testBrokerFailure PASSED kafka.admin.AddPartitionsTest > testTopicDoesNotExist PASSED kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooLow PASSED kafka.admin.DeleteConsumerGroupTest > testConsumptionOnRecreatedTopicAfterTopicWideDeleteInZK PASSED kafka.api.ProducerSendTest > testCloseWithZeroTimeoutFromSenderThread PASSED kafka.utils.SchedulerTest > testMockSchedulerPeriodicTask PASSED kafka.utils.SchedulerTest > testMockSchedulerNonPeriodicTask PASSED kafka.utils.SchedulerTest > testNonPeriodicTask PASSED kafka.utils.SchedulerTest > testPeriodicTask PASSED kafka.utils.SchedulerTest > testReentrantTaskInMockScheduler PASSED kafka.utils.SchedulerTest > testRestart PASSED kafka.utils.timer.TimerTest > testTaskExpiration PASSED kafka.utils.timer.TimerTest > testAlreadyExpiredTask PASSED kafka.integration.TopicMetadataTest > testTopicMetadataRequest PASSED kafka.log.LogTest > testCorruptLog PASSED kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooLow PASSED kafka.integration.FetcherTest > testFetcher PASSED kafka.common.ConfigTest > testInvalidClientIds PASSED kafka.common.ConfigTest > testInvalidGroupIds 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.admin.AdminTest > testPartitionReassignmentNonOverlappingReplicas PASSED kafka.admin.DeleteTopicTest > testDeleteNonExistingTopic PASSED kafka.log.LogCleanerIntegrationTest > cleanerTest[0] PASSED kafka.api.ConsumerTest > testPauseStateNotPreservedByRebalance PASSED kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooHigh PASSED kafka.api.ProducerFailureHandlingTest > testTooLargeRecordWithAckZero PASSED kafka.admin.AdminTest > testReassigningNonExistingPartition PASSED kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooHigh PASSED kafka.admin.DeleteTopicTest > testResumeDeleteTopicWithRecoveredFollower PASSED kafka.admin.AddPartitionsTest > testReplicaPlacement PASSED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionInvalidTopicOverride PASSED kafka.api.ProducerFailureHandlingTest > testTooLargeRecordWithAckOne PASSED kafka.api.ProducerFailureHandlingTest > testNonExistentTopic PASSED kafka.api.ConsumerBounceTest > testConsumptionWithBrokerFailures PASSED kafka.utils.IteratorTemplateTest > testIterator PASSED kafka.integration.RollingBounceTest > testRollingBounce PASSED kafka.common.TopicTest > testTopicHasCollisionChars PASSED kafka.common.TopicTest > testInvalidTopicNames PASSED kafka.common.TopicTest > testTopicHasCollision PASSED kafka.api.ConsumerTest > testSimpleConsumption PASSED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabledByTopicOverride PASSED kafka.api.ProducerFailureHandlingTest > testWrongBrokerList PASSED kafka.api.ConsumerTest > testCommitSpecifiedOffsets PASSED kafka.log.LogCleanerIntegrationTest > cleanerTest[1] PASSED kafka.api.ProducerFailureHandlingTest > testNoResponse PASSED kafka.admin.DeleteTopicTest > testDeleteTopicWithCleaner PASSED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabled PASSED kafka.api.ConsumerTest > testAutoOffsetReset PASSED kafka.api.ProducerFailureHandlingTest > testInvalidPartition PASSED kafka.api.ProducerFailureHandlingTest > testSendAfterClosed PASSED kafka.admin.DeleteTopicTest > testDeleteTopicAlreadyMarkedAsDeleted PASSED kafka.integration.PrimitiveApiTest > testFetchRequestCanProperlySerialize PASSED kafka.api.ConsumerTest > testSeek PASSED kafka.api.ProducerFailureHandlingTest > testCannotSendToInternalTopic PASSED kafka.integration.PrimitiveApiTest > testPipelinedProduceRequests PASSED kafka.api.ProducerFailureHandlingTest > testNotEnoughReplicas PASSED kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetchWithCompression PASSED kafka.api.ConsumerTest > testGroupConsumption PASSED kafka.integration.PrimitiveApiTest > testConsumerEmptyTopic PASSED kafka.api.ProducerFailureHandlingTest > testNotEnoughReplicasAfterBrokerShutdown PASSED kafka.utils.ByteBoundedBlockingQueueTest > testByteBoundedBlockingQueue PASSED kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetch PASSED kafka.log.LogCleanerIntegrationTest > cleanerTest[2] PASSED kafka.integration.PrimitiveApiTest > testEmptyFetchRequest PASSED kafka.api.ConsumerTest > testPositionAndCommit PASSED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionDisabled PASSED kafka.integration.PrimitiveApiTest > testMultiProduce PASSED kafka.integration.PrimitiveApiTest > testProduceAndMultiFetch PASSED kafka.api.ConsumerTest > testPartitionsFor PASSED kafka.api.ConsumerTest > testListTopics PASSED kafka.log.LogCleanerIntegrationTest > cleanerTest[3] PASSED kafka.api.ConsumerTest > testPartitionReassignmentCallback PASSED kafka.integration.UncleanLeaderElectionTest > testCleanLeaderElectionDisabledByTopicOverride PASSED kafka.zk.ZKEphemeralTest > testEphemeralNodeCleanup PASSED kafka.log.LogManagerTest > testCleanupExpiredSegments PASSED kafka.log.LogManagerTest > testRecoveryDirectoryMappingWithRelativeDirectory PASSED kafka.api.SSLConsumerTest > testSimpleConsumption PASSED kafka.api.ConsumerTest > testUnsubscribeTopic PASSED kafka.api.SSLProducerSendTest > testClose PASSED kafka.api.SSLProducerSendTest > testSendToPartition PASSED kafka.api.ConsumerTest > testExpandingTopicSubscriptions PASSED kafka.utils.CommandLineUtilsTest > testParseSingleArg PASSED kafka.utils.CommandLineUtilsTest > testParseArgs PASSED kafka.utils.CommandLineUtilsTest > testParseEmptyArg PASSED kafka.api.SSLConsumerTest > testGroupConsumption PASSED kafka.api.SSLProducerSendTest > testSendOffset PASSED kafka.utils.ReplicationUtilsTest > testUpdateLeaderAndIsr PASSED kafka.utils.ReplicationUtilsTest > testGetLeaderIsrAndEpochForPartition PASSED kafka.api.SSLConsumerTest > testPositionAndCommit PASSED kafka.api.SSLConsumerTest > testPartitionsFor PASSED kafka.api.SSLConsumerTest > testAutoOffsetReset PASSED kafka.api.SSLConsumerTest > testSeek PASSED kafka.message.MessageWriterTest > testWithNoCompressionAttribute PASSED kafka.message.MessageWriterTest > testBufferingOutputStream PASSED kafka.message.MessageWriterTest > testWithCompressionAttribute PASSED kafka.message.MessageWriterTest > testWithKey PASSED 512 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:///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: 4 mins 58.778 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