See <https://builds.apache.org/job/kafka-trunk-jdk7/1651/changes>
Changes: [me] MINOR: Check for null timestamp rather than value in hashcode ------------------------------------------ [...truncated 14166 lines...] org.apache.kafka.streams.kstream.JoinWindowsTest > timeDifferenceMustNotBeNegative STARTED org.apache.kafka.streams.kstream.JoinWindowsTest > timeDifferenceMustNotBeNegative PASSED org.apache.kafka.streams.kstream.KStreamBuilderTest > shouldHaveCorrectSourceTopicsForTableFromMergedStream STARTED org.apache.kafka.streams.kstream.KStreamBuilderTest > shouldHaveCorrectSourceTopicsForTableFromMergedStream PASSED org.apache.kafka.streams.kstream.KStreamBuilderTest > shouldHaveCorrectSourceTopicsForTableFromMergedStreamWithProcessors STARTED org.apache.kafka.streams.kstream.KStreamBuilderTest > shouldHaveCorrectSourceTopicsForTableFromMergedStreamWithProcessors PASSED 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 > shouldThrowStreamsExceptionIfValueSerdeConfigFails STARTED org.apache.kafka.streams.StreamsConfigTest > shouldThrowStreamsExceptionIfValueSerdeConfigFails PASSED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedProducerConfigs STARTED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedProducerConfigs PASSED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedPropertiesThatAreNotPartOfRestoreConsumerConfig STARTED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedPropertiesThatAreNotPartOfRestoreConsumerConfig PASSED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedPropertiesThatAreNotPartOfProducerConfig STARTED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedPropertiesThatAreNotPartOfProducerConfig PASSED org.apache.kafka.streams.StreamsConfigTest > shouldBeSupportNonPrefixedConsumerConfigs STARTED org.apache.kafka.streams.StreamsConfigTest > shouldBeSupportNonPrefixedConsumerConfigs PASSED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedPropertiesThatAreNotPartOfConsumerConfig STARTED org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedPropertiesThatAreNotPartOfConsumerConfig PASSED org.apache.kafka.streams.StreamsConfigTest > shouldSupportMultipleBootstrapServers STARTED org.apache.kafka.streams.StreamsConfigTest > shouldSupportMultipleBootstrapServers PASSED org.apache.kafka.streams.StreamsConfigTest > shouldThrowStreamsExceptionIfKeySerdeConfigFails STARTED org.apache.kafka.streams.StreamsConfigTest > shouldThrowStreamsExceptionIfKeySerdeConfigFails 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 > 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] PASSED 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 :streams:test FAILED FAILURE: Build failed with an exception. * What went wrong: Execution failed for task ':streams:test'. > Process 'Gradle Test Executor 4' finished with non-zero exit value 1 * 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 39 mins 16.054 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