Return-Path: X-Original-To: archive-asf-public-internal@cust-asf2.ponee.io Delivered-To: archive-asf-public-internal@cust-asf2.ponee.io Received: from cust-asf.ponee.io (cust-asf.ponee.io [163.172.22.183]) by cust-asf2.ponee.io (Postfix) with ESMTP id A8D70200BF1 for ; Tue, 3 Jan 2017 13:46:54 +0100 (CET) Received: by cust-asf.ponee.io (Postfix) id A777A160B43; Tue, 3 Jan 2017 12:46:54 +0000 (UTC) Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by cust-asf.ponee.io (Postfix) with SMTP id A789F160B33 for ; Tue, 3 Jan 2017 13:46:53 +0100 (CET) Received: (qmail 95206 invoked by uid 500); 3 Jan 2017 12:46:52 -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 95192 invoked by uid 99); 3 Jan 2017 12:46:52 -0000 Received: from crius.apache.org (HELO crius.apache.org) (140.211.11.14) by apache.org (qpsmtpd/0.29) with ESMTP; Tue, 03 Jan 2017 12:46:52 +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 85D859C005B; Tue, 3 Jan 2017 12:46:49 +0000 (UTC) Date: Tue, 3 Jan 2017 12:46:49 +0000 (UTC) From: Apache Jenkins Server To: dev@kafka.apache.org, wangguoz@gmail.com, me@ewencp.org, ismael@juma.me.uk Message-ID: <690102985.6174.1483447609397.JavaMail.jenkins@crius> In-Reply-To: <895798907.5670.1483220191563.JavaMail.jenkins@crius> References: <895798907.5670.1483220191563.JavaMail.jenkins@crius> Subject: Build failed in Jenkins: kafka-trunk-jdk8 #1138 MIME-Version: 1.0 Content-Type: text/plain; charset=UTF-8 Content-Transfer-Encoding: 7bit X-Instance-Identity: MIIBIjANBgkqhkiG9w0BAQEFAAOCAQ8AMIIBCgKCAQEAkqVKZPv7YyHBB3FvWfV7XQehwe/Ga3aadzSNknt8g382X3uN8A3SOQ+Ixq9HxS+ZlN6XR4TECySmSRy2JN5Rx8svxAD0TjtSF9LuU98dD+LniNDP7Lq6gvRFuJhbMHoS0nuTizDZLsK4X8TW5MyV9w+jFbdoZfRE5O/Mse0fkOeL5uoIS/3Vvu/W+x9QSjDkB7CaU56bPFlQjqqJBl3Cn9r34CkXQZYnLb/NjW4vcpw0+TgMUAPTIVEr5BTPZRshz19g7huwg3zANT5HBIZnzV4hsVY9w4JHkceFdKi/ibNnjPjsFs9pm0HSGJ/RDxjIvSTYT02eH4+m1RAYaj2E9QIDAQAB X-Jenkins-Job: kafka-trunk-jdk8 X-Jenkins-Result: FAILURE archived-at: Tue, 03 Jan 2017 12:46:54 -0000 See Changes: [ismael] MINOR: Scala code readability improvements ------------------------------------------ [...truncated 17626 lines...] org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetAllTasksWithStoreWhenNotRunning STARTED org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetAllTasksWithStoreWhenNotRunning PASSED org.apache.kafka.streams.KafkaStreamsTest > testCannotStartOnceClosed STARTED org.apache.kafka.streams.KafkaStreamsTest > testCannotStartOnceClosed PASSED org.apache.kafka.streams.KafkaStreamsTest > testCleanup STARTED org.apache.kafka.streams.KafkaStreamsTest > testCleanup PASSED org.apache.kafka.streams.KafkaStreamsTest > testStartAndClose STARTED org.apache.kafka.streams.KafkaStreamsTest > testStartAndClose PASSED org.apache.kafka.streams.KafkaStreamsTest > testCloseIsIdempotent STARTED org.apache.kafka.streams.KafkaStreamsTest > testCloseIsIdempotent PASSED org.apache.kafka.streams.KafkaStreamsTest > testCannotCleanupWhileRunning STARTED org.apache.kafka.streams.KafkaStreamsTest > testCannotCleanupWhileRunning PASSED org.apache.kafka.streams.KafkaStreamsTest > testCannotStartTwice STARTED org.apache.kafka.streams.KafkaStreamsTest > testCannotStartTwice PASSED org.apache.kafka.streams.integration.KStreamKTableJoinIntegrationTest > shouldCountClicksPerRegion[0] STARTED org.apache.kafka.streams.integration.KStreamKTableJoinIntegrationTest > shouldCountClicksPerRegion[0] PASSED org.apache.kafka.streams.integration.KStreamKTableJoinIntegrationTest > shouldCountClicksPerRegion[1] STARTED org.apache.kafka.streams.integration.KStreamKTableJoinIntegrationTest > shouldCountClicksPerRegion[1] PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldBeAbleToQueryState[0] STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldBeAbleToQueryState[0] PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldNotMakeStoreAvailableUntilAllStoresAvailable[0] STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldNotMakeStoreAvailableUntilAllStoresAvailable[0] PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > queryOnRebalance[0] STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > queryOnRebalance[0] FAILED java.lang.AssertionError: Condition not met within timeout 60000. Did not receive 1 number of records at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:259) at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinValuesRecordsReceived(IntegrationTestUtils.java:251) at org.apache.kafka.streams.integration.QueryableStateIntegrationTest.waitUntilAtLeastNumRecordProcessed(QueryableStateIntegrationTest.java:669) at org.apache.kafka.streams.integration.QueryableStateIntegrationTest.queryOnRebalance(QueryableStateIntegrationTest.java:350) org.apache.kafka.streams.integration.QueryableStateIntegrationTest > concurrentAccesses[0] STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > concurrentAccesses[0] PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldBeAbleToQueryState[1] STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldBeAbleToQueryState[1] PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldNotMakeStoreAvailableUntilAllStoresAvailable[1] STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldNotMakeStoreAvailableUntilAllStoresAvailable[1] PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > queryOnRebalance[1] STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > queryOnRebalance[1] PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > concurrentAccesses[1] STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > concurrentAccesses[1] PASSED org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testShouldReadFromRegexAndNamedTopics STARTED org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testShouldReadFromRegexAndNamedTopics PASSED org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testRegexMatchesTopicsAWhenCreated STARTED org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testRegexMatchesTopicsAWhenCreated PASSED org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testMultipleConsumersCanReadFromPartitionedTopic STARTED org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testMultipleConsumersCanReadFromPartitionedTopic PASSED org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testRegexMatchesTopicsAWhenDeleted STARTED org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testRegexMatchesTopicsAWhenDeleted PASSED org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testNoMessagesSentExceptionFromOverlappingPatterns STARTED org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testNoMessagesSentExceptionFromOverlappingPatterns PASSED org.apache.kafka.streams.integration.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperations[0] STARTED org.apache.kafka.streams.integration.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperations[0] PASSED org.apache.kafka.streams.integration.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperations[1] STARTED org.apache.kafka.streams.integration.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperations[1] PASSED org.apache.kafka.streams.integration.InternalTopicIntegrationTest > shouldCompactTopicsForStateChangelogs STARTED org.apache.kafka.streams.integration.InternalTopicIntegrationTest > shouldCompactTopicsForStateChangelogs PASSED org.apache.kafka.streams.integration.InternalTopicIntegrationTest > shouldUseCompactAndDeleteForWindowStoreChangelogs STARTED org.apache.kafka.streams.integration.InternalTopicIntegrationTest > shouldUseCompactAndDeleteForWindowStoreChangelogs PASSED org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduce STARTED org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduce PASSED org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregate STARTED org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregate PASSED org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCount STARTED org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCount PASSED org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldGroupByKey STARTED org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldGroupByKey PASSED org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduceWindowed STARTED org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduceWindowed PASSED org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregateWindowed STARTED org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregateWindowed PASSED org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithIntermediateUserTopic STARTED org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithIntermediateUserTopic PASSED org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithoutIntermediateUserTopic STARTED org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithoutIntermediateUserTopic PASSED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[0] STARTED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[0] PASSED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[1] STARTED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[1] PASSED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[2] STARTED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[2] PASSED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[3] STARTED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[3] PASSED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[4] STARTED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[4] PASSED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[5] STARTED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[5] PASSED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[6] STARTED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[6] PASSED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[7] STARTED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[7] PASSED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[8] STARTED org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > KTableKTableJoin[8] PASSED org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldReduce STARTED org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldReduce PASSED org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldGroupByKey STARTED org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldGroupByKey PASSED org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldReduceWindowed STARTED org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldReduceWindowed PASSED org.apache.kafka.streams.integration.FanoutIntegrationTest > shouldFanoutTheInput[0] STARTED org.apache.kafka.streams.integration.FanoutIntegrationTest > shouldFanoutTheInput[0] PASSED org.apache.kafka.streams.integration.FanoutIntegrationTest > shouldFanoutTheInput[1] STARTED org.apache.kafka.streams.integration.FanoutIntegrationTest > shouldFanoutTheInput[1] PASSED org.apache.kafka.streams.integration.JoinIntegrationTest > testInnerKTableKTable STARTED org.apache.kafka.streams.integration.JoinIntegrationTest > testInnerKTableKTable PASSED org.apache.kafka.streams.integration.JoinIntegrationTest > testLeftKTableKTable STARTED org.apache.kafka.streams.integration.JoinIntegrationTest > testLeftKTableKTable PASSED org.apache.kafka.streams.integration.JoinIntegrationTest > testLeftKStreamKStream STARTED org.apache.kafka.streams.integration.JoinIntegrationTest > testLeftKStreamKStream PASSED org.apache.kafka.streams.integration.JoinIntegrationTest > testLeftKStreamKTable STARTED org.apache.kafka.streams.integration.JoinIntegrationTest > testLeftKStreamKTable PASSED org.apache.kafka.streams.integration.JoinIntegrationTest > testOuterKTableKTable STARTED org.apache.kafka.streams.integration.JoinIntegrationTest > testOuterKTableKTable PASSED org.apache.kafka.streams.integration.JoinIntegrationTest > testInnerKStreamKStream STARTED org.apache.kafka.streams.integration.JoinIntegrationTest > testInnerKStreamKStream PASSED org.apache.kafka.streams.integration.JoinIntegrationTest > testOuterKStreamKStream STARTED org.apache.kafka.streams.integration.JoinIntegrationTest > testOuterKStreamKStream PASSED org.apache.kafka.streams.integration.JoinIntegrationTest > testInnerKStreamKTable STARTED org.apache.kafka.streams.integration.JoinIntegrationTest > testInnerKStreamKTable PASSED 566 tests completed, 1 failed :streams:test FAILED FAILURE: Build failed with an exception. * What went wrong: Execution failed for task ':streams:test'. > There were failing tests. See the report at: file:// * 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: 1 hrs 32 mins 34.046 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