See <https://builds.apache.org/job/kafka-trunk-jdk8/877/changes>
Changes: [wangguoz] MINOR: catch InvalidStateStoreException in QueryableStateIntegrationTest ------------------------------------------ [...truncated 12374 lines...] org.apache.kafka.streams.kstream.KStreamBuilderTest > testMerge STARTED org.apache.kafka.streams.kstream.KStreamBuilderTest > testMerge PASSED org.apache.kafka.streams.kstream.KStreamBuilderTest > testFrom STARTED org.apache.kafka.streams.kstream.KStreamBuilderTest > testFrom PASSED org.apache.kafka.streams.kstream.KStreamBuilderTest > shouldThrowExceptionWhenTopicNamesAreNull STARTED org.apache.kafka.streams.kstream.KStreamBuilderTest > shouldThrowExceptionWhenTopicNamesAreNull PASSED org.apache.kafka.streams.kstream.KStreamBuilderTest > shouldThrowExceptionWhenNoTopicPresent STARTED org.apache.kafka.streams.kstream.KStreamBuilderTest > shouldThrowExceptionWhenNoTopicPresent PASSED org.apache.kafka.streams.kstream.KStreamBuilderTest > testNewName STARTED org.apache.kafka.streams.kstream.KStreamBuilderTest > testNewName PASSED org.apache.kafka.streams.kstream.TimeWindowsTest > shouldHaveSaneEqualsAndHashCode STARTED org.apache.kafka.streams.kstream.TimeWindowsTest > shouldHaveSaneEqualsAndHashCode PASSED org.apache.kafka.streams.kstream.TimeWindowsTest > windowSizeMustNotBeZero STARTED org.apache.kafka.streams.kstream.TimeWindowsTest > windowSizeMustNotBeZero PASSED org.apache.kafka.streams.kstream.TimeWindowsTest > advanceIntervalMustNotBeZero STARTED org.apache.kafka.streams.kstream.TimeWindowsTest > advanceIntervalMustNotBeZero PASSED org.apache.kafka.streams.kstream.TimeWindowsTest > windowSizeMustNotBeNegative STARTED org.apache.kafka.streams.kstream.TimeWindowsTest > windowSizeMustNotBeNegative PASSED org.apache.kafka.streams.kstream.TimeWindowsTest > advanceIntervalMustNotBeNegative STARTED org.apache.kafka.streams.kstream.TimeWindowsTest > advanceIntervalMustNotBeNegative PASSED org.apache.kafka.streams.kstream.TimeWindowsTest > advanceIntervalMustNotBeLargerThanWindowSize STARTED org.apache.kafka.streams.kstream.TimeWindowsTest > advanceIntervalMustNotBeLargerThanWindowSize PASSED org.apache.kafka.streams.kstream.TimeWindowsTest > windowsForTumblingWindows STARTED org.apache.kafka.streams.kstream.TimeWindowsTest > windowsForTumblingWindows PASSED org.apache.kafka.streams.kstream.TimeWindowsTest > windowsForHoppingWindows STARTED org.apache.kafka.streams.kstream.TimeWindowsTest > windowsForHoppingWindows PASSED org.apache.kafka.streams.kstream.TimeWindowsTest > windowsForBarelyOverlappingHoppingWindows STARTED org.apache.kafka.streams.kstream.TimeWindowsTest > windowsForBarelyOverlappingHoppingWindows PASSED org.apache.kafka.streams.StreamsConfigTest > testGetConsumerConfigs STARTED org.apache.kafka.streams.StreamsConfigTest > testGetConsumerConfigs PASSED org.apache.kafka.streams.StreamsConfigTest > defaultSerdeShouldBeConfigured STARTED org.apache.kafka.streams.StreamsConfigTest > defaultSerdeShouldBeConfigured PASSED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedConsumerConfigs STARTED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedConsumerConfigs PASSED org.apache.kafka.streams.StreamsConfigTest > testGetProducerConfigs STARTED org.apache.kafka.streams.StreamsConfigTest > testGetProducerConfigs PASSED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedProducerConfigs STARTED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedProducerConfigs PASSED org.apache.kafka.streams.StreamsConfigTest > shouldBeSupportNonPrefixedConsumerConfigs STARTED org.apache.kafka.streams.StreamsConfigTest > shouldBeSupportNonPrefixedConsumerConfigs PASSED org.apache.kafka.streams.StreamsConfigTest > shouldSupportMultipleBootstrapServers STARTED org.apache.kafka.streams.StreamsConfigTest > shouldSupportMultipleBootstrapServers PASSED org.apache.kafka.streams.StreamsConfigTest > shouldSupportNonPrefixedProducerConfigs STARTED org.apache.kafka.streams.StreamsConfigTest > shouldSupportNonPrefixedProducerConfigs PASSED org.apache.kafka.streams.StreamsConfigTest > testGetRestoreConsumerConfigs STARTED org.apache.kafka.streams.StreamsConfigTest > testGetRestoreConsumerConfigs PASSED org.apache.kafka.streams.StreamsConfigTest > shouldBeSupportNonPrefixedRestoreConsumerConfigs STARTED org.apache.kafka.streams.StreamsConfigTest > shouldBeSupportNonPrefixedRestoreConsumerConfigs PASSED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedRestoreConsumerConfigs STARTED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedRestoreConsumerConfigs PASSED org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetAllTasksWhenNotRunning STARTED org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetAllTasksWhenNotRunning PASSED org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetTaskWithKeyAndPartitionerWhenNotRunning STARTED org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetTaskWithKeyAndPartitionerWhenNotRunning PASSED org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetTaskWithKeyAndSerializerWhenNotRunning STARTED org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetTaskWithKeyAndSerializerWhenNotRunning PASSED 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 > testCleanupIsolation STARTED org.apache.kafka.streams.KafkaStreamsTest > testCleanupIsolation 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 STARTED org.apache.kafka.streams.integration.KStreamKTableJoinIntegrationTest > shouldCountClicksPerRegion PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldBeAbleToQueryState STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldBeAbleToQueryState PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldNotMakeStoreAvailableUntilAllStoresAvailable STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldNotMakeStoreAvailableUntilAllStoresAvailable PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > queryOnRebalance STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > queryOnRebalance PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > concurrentAccesses STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > concurrentAccesses 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 > 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 STARTED org.apache.kafka.streams.integration.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperations FAILED java.lang.AssertionError: Condition not met within timeout 60000. Did not receive 5 number of records at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:268) at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinValuesRecordsReceived(IntegrationTestUtils.java:251) at org.apache.kafka.streams.integration.KStreamRepartitionJoinTest.receiveMessages(KStreamRepartitionJoinTest.java:378) at org.apache.kafka.streams.integration.KStreamRepartitionJoinTest.verifyCorrectOutput(KStreamRepartitionJoinTest.java:288) at org.apache.kafka.streams.integration.KStreamRepartitionJoinTest.shouldCorrectlyRepartitionOnJoinOperations(KStreamRepartitionJoinTest.java:129) 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 > testReprocessingFromScratchAfterReset STARTED org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterReset PASSED org.apache.kafka.streams.integration.FanoutIntegrationTest > shouldFanoutTheInput STARTED org.apache.kafka.streams.integration.FanoutIntegrationTest > shouldFanoutTheInput PASSED 377 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://<https://builds.apache.org/job/kafka-trunk-jdk8/ws/streams/build/reports/tests/test/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: 1 hrs 20 mins 41.618 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