You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@kafka.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2017/01/13 23:09:42 UTC

Build failed in Jenkins: kafka-trunk-jdk7 #1835

See <https://builds.apache.org/job/kafka-trunk-jdk7/1835/changes>

Changes:

[jason] KAFKA-4565; Separation of Internal and External traffic (KIP-103)

[me] MINOR: Cluster file generator should produce valid json

[ismael] MINOR: Remove unneeded client used API lists

[jason] KAFKA-4627; Fix timing issue in consumer close tests

[wangguoz] HOTFIX: Added another broker to smoke test

[wangguoz] KAFKA-3739: Add no-arg constructor for WindowedSerdes in Streams

[wangguoz] MINOR: Remove unnecessary store info from TopologyBuilder

[me] KAFKA-4381: Add per partition lag metrics to the consumer

------------------------------------------
[...truncated 18848 lines...]
org.apache.kafka.streams.processor.internals.assignment.TaskAssignorTest > testAssignWithStandby PASSED

org.apache.kafka.streams.processor.internals.assignment.TaskAssignorTest > testAssignWithoutStandby STARTED

org.apache.kafka.streams.processor.internals.assignment.TaskAssignorTest > testAssignWithoutStandby PASSED

org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfoTest > testEncodeDecode STARTED

org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfoTest > testEncodeDecode PASSED

org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfoTest > shouldEncodeDecodeWithUserEndPoint STARTED

org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfoTest > shouldEncodeDecodeWithUserEndPoint PASSED

org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfoTest > shouldBeBackwardCompatible STARTED

org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfoTest > shouldBeBackwardCompatible PASSED

org.apache.kafka.streams.processor.internals.assignment.AssignmentInfoTest > testEncodeDecode STARTED

org.apache.kafka.streams.processor.internals.assignment.AssignmentInfoTest > testEncodeDecode PASSED

org.apache.kafka.streams.processor.internals.assignment.AssignmentInfoTest > shouldDecodePreviousVersion STARTED

org.apache.kafka.streams.processor.internals.assignment.AssignmentInfoTest > shouldDecodePreviousVersion PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCleanUpTaskStateDirectoriesThatAreNotCurrentlyLocked STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCleanUpTaskStateDirectoriesThatAreNotCurrentlyLocked PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCreateBaseDirectory STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCreateBaseDirectory PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldLockMulitpleTaskDirectories STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldLockMulitpleTaskDirectories PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCreateDirectoriesIfParentDoesntExist STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCreateDirectoriesIfParentDoesntExist PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldUnlockGlobalStateDirectory STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldUnlockGlobalStateDirectory PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldListAllTaskDirectories STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldListAllTaskDirectories PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldLockTaskStateDirectory STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldLockTaskStateDirectory PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldLockGlobalStateDirectory STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldLockGlobalStateDirectory PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCreateTaskStateDirectory STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCreateTaskStateDirectory PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldNotRemoveNonTaskDirectoriesAndFiles STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldNotRemoveNonTaskDirectoriesAndFiles PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldBeTrueIfAlreadyHoldsLock STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldBeTrueIfAlreadyHoldsLock PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldReleaseTaskStateDirectoryLock STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldReleaseTaskStateDirectoryLock PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowStreamsExceptionIfNoPartitionsFoundForStore STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowStreamsExceptionIfNoPartitionsFoundForStore PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldNotCloseStoresIfCloseAlreadyCalled STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldNotCloseStoresIfCloseAlreadyCalled PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowProcessorStateStoreExceptionIfStoreFlushFailed STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowProcessorStateStoreExceptionIfStoreFlushFailed PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowStreamsExceptionIfCantGetLock STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowStreamsExceptionIfCantGetLock PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowStreamsExceptionIfFailedToReadCheckpointedOffsets STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowStreamsExceptionIfFailedToReadCheckpointedOffsets PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldWriteCheckpointsOnClose STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldWriteCheckpointsOnClose PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowProcessorStateStoreExceptionIfStoreCloseFailed STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowProcessorStateStoreExceptionIfStoreCloseFailed PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldRestoreRecordsUpToHighwatermark STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldRestoreRecordsUpToHighwatermark PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldInitializeStateStores STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldInitializeStateStores PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldReturnInitializedStoreNames STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldReturnInitializedStoreNames PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldUnlockGlobalStateDirectoryOnClose STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldUnlockGlobalStateDirectoryOnClose PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowIllegalArgumenExceptionIfAttemptingToRegisterStoreTwice STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowIllegalArgumenExceptionIfAttemptingToRegisterStoreTwice PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldAttemptToCloseAllStoresEvenWhenSomeException STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldAttemptToCloseAllStoresEvenWhenSomeException PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowIllegalArgumentExceptionIfCallbackIsNull STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowIllegalArgumentExceptionIfCallbackIsNull PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldReadCheckpointOffsets STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldReadCheckpointOffsets PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldCloseStateStores STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldCloseStateStores PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowIllegalArgumentIfTryingToRegisterStoreThatIsNotGlobal STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldThrowIllegalArgumentIfTryingToRegisterStoreThatIsNotGlobal PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldFlushStateStores STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldFlushStateStores PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldLockGlobalStateDirectory STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldLockGlobalStateDirectory PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldRestoreRecordsFromCheckpointToHighwatermark STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldRestoreRecordsFromCheckpointToHighwatermark PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldDeleteCheckpointFileAfteLoaded STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldDeleteCheckpointFileAfteLoaded PASSED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldReleaseLockIfExceptionWhenLoadingCheckpoints STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldReleaseLockIfExceptionWhenLoadingCheckpoints PASSED

org.apache.kafka.streams.processor.WallclockTimestampExtractorTest > extractSystemTimestamp STARTED

org.apache.kafka.streams.processor.WallclockTimestampExtractorTest > extractSystemTimestamp PASSED

org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestampTest > usePreviousTimeOnInvalidTimestamp STARTED

org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestampTest > usePreviousTimeOnInvalidTimestamp PASSED

org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestampTest > extractMetadataTimestamp STARTED

org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestampTest > extractMetadataTimestamp PASSED

org.apache.kafka.streams.KafkaStreamsTest > testIllegalMetricsConfig STARTED

org.apache.kafka.streams.KafkaStreamsTest > testIllegalMetricsConfig PASSED

org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetAllTasksWhenNotRunning STARTED

org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetAllTasksWhenNotRunning PASSED

org.apache.kafka.streams.KafkaStreamsTest > testInitializesAndDestroysMetricsReporters STARTED

org.apache.kafka.streams.KafkaStreamsTest > testInitializesAndDestroysMetricsReporters PASSED

org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetTaskWithKeyAndPartitionerWhenNotRunning STARTED

org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetTaskWithKeyAndPartitionerWhenNotRunning PASSED

org.apache.kafka.streams.KafkaStreamsTest > testLegalMetricsConfig STARTED

org.apache.kafka.streams.KafkaStreamsTest > testLegalMetricsConfig PASSED

org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetTaskWithKeyAndSerializerWhenNotRunning STARTED

org.apache.kafka.streams.KafkaStreamsTest > shouldNotGetTaskWithKeyAndSerializerWhenNotRunning PASSED

org.apache.kafka.streams.KafkaStreamsTest > shouldReturnFalseOnCloseWhenThreadsHaventTerminated STARTED

org.apache.kafka.streams.KafkaStreamsTest > shouldReturnFalseOnCloseWhenThreadsHaventTerminated 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 > testNumberDefaultMetrics STARTED

org.apache.kafka.streams.KafkaStreamsTest > testNumberDefaultMetrics 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

763 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-jdk7/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 30 mins 11.273 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

Jenkins build is back to normal : kafka-trunk-jdk7 #1837

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/kafka-trunk-jdk7/1837/changes>


Build failed in Jenkins: kafka-trunk-jdk7 #1836

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/kafka-trunk-jdk7/1836/changes>

Changes:

[jason] KAFKA-3853; Extend OffsetFetch API to allow fetching all offsets for a

------------------------------------------
[...truncated 18591 lines...]
org.apache.kafka.streams.processor.TopologyBuilderTest > shouldAddInternalTopicConfigWithCompactAndDeleteSetForWindowStores PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldAddInternalTopicConfigWithCompactForNonWindowStores STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldAddInternalTopicConfigWithCompactForNonWindowStores PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSinkWithSameName STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSinkWithSameName PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSinkWithSelfParent STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSinkWithSelfParent PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddProcessorWithSelfParent STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddProcessorWithSelfParent PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldAssociateStateStoreNameWhenStateStoreSupplierIsInternal STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldAssociateStateStoreNameWhenStateStoreSupplierIsInternal PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddStateStoreWithSink STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddStateStoreWithSink PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testTopicGroups STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testTopicGroups PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testBuild STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testBuild PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldNotAddNullStateStoreSupplier STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldNotAddNullStateStoreSupplier PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldNotAllowNullNameWhenAddingSource STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldNotAllowNullNameWhenAddingSource PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldNotAllowNullTopicWhenAddingSink STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldNotAllowNullTopicWhenAddingSink PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddStateStoreWithSource STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddStateStoreWithSource PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldThroughOnUnassignedStateStoreAccess STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldThroughOnUnassignedStateStoreAccess PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldNotAllowNullProcessorNameWhenConnectingProcessorAndStateStores STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldNotAllowNullProcessorNameWhenConnectingProcessorAndStateStores PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSourceWithSameName STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSourceWithSameName PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddMoreThanOnePatternSourceNode STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddMoreThanOnePatternSourceNode PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddProcessorWithSameName STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddProcessorWithSameName PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldSetCorrectSourceNodesWithRegexUpdatedTopics STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldSetCorrectSourceNodesWithRegexUpdatedTopics PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSourceWithSameTopic STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSourceWithSameTopic PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testTopicGroupsByStateStore STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testTopicGroupsByStateStore PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddStateStoreWithDuplicates STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddStateStoreWithDuplicates PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testPatternSourceTopic STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testPatternSourceTopic PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldAssociateStateStoreNameWhenStateStoreSupplierIsExternal STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldAssociateStateStoreNameWhenStateStoreSupplierIsExternal PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSinkWithWrongParent STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSinkWithWrongParent PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testPatternMatchesAlreadyProvidedTopicSource STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testPatternMatchesAlreadyProvidedTopicSource PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSinkConnectedWithMultipleParent STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSinkConnectedWithMultipleParent PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testSubscribeTopicNameAndPattern STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testSubscribeTopicNameAndPattern PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldNotAddNullInternalTopic STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldNotAddNullInternalTopic PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddProcessorWithWrongParent STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddProcessorWithWrongParent PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldNotAllowNullNameWhenAddingProcessor STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldNotAllowNullNameWhenAddingProcessor PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddStateStore STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddStateStore PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSinkConnectedWithParent STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddSinkConnectedWithParent PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddStateStoreWithNonExistingProcessor STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > testAddStateStoreWithNonExistingProcessor PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldAddInternalTopicConfigWithCleanupPolicyDeleteForInternalTopics STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldAddInternalTopicConfigWithCleanupPolicyDeleteForInternalTopics PASSED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldCorrectlyMapStateStoreToInternalTopics STARTED

org.apache.kafka.streams.processor.TopologyBuilderTest > shouldCorrectlyMapStateStoreToInternalTopics PASSED

org.apache.kafka.streams.processor.FailOnInvalidTimestampTest > failOnInvalidTimestamp STARTED

org.apache.kafka.streams.processor.FailOnInvalidTimestampTest > failOnInvalidTimestamp PASSED

org.apache.kafka.streams.processor.FailOnInvalidTimestampTest > extractMetadataTimestamp STARTED

org.apache.kafka.streams.processor.FailOnInvalidTimestampTest > extractMetadataTimestamp PASSED

org.apache.kafka.streams.KeyValueTest > shouldHaveSaneEqualsAndHashCode STARTED

org.apache.kafka.streams.KeyValueTest > shouldHaveSaneEqualsAndHashCode 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.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 FAILED
    java.lang.AssertionError: Condition not met within timeout 30000. 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:253)
        at org.apache.kafka.streams.integration.JoinIntegrationTest.checkResult(JoinIntegrationTest.java:168)
        at org.apache.kafka.streams.integration.JoinIntegrationTest.runTest(JoinIntegrationTest.java:190)
        at org.apache.kafka.streams.integration.JoinIntegrationTest.testInnerKStreamKTable(JoinIntegrationTest.java:302)

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithIntermediateUserTopic STARTED

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithIntermediateUserTopic FAILED
    java.lang.AssertionError: Condition not met within timeout 30000. Did not receive 10 number of records
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:259)
        at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:213)
        at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:182)
        at org.apache.kafka.streams.integration.ResetIntegrationTest.testReprocessingFromScratchAfterResetWithIntermediateUserTopic(ResetIntegrationTest.java:160)

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithoutIntermediateUserTopic STARTED
ERROR: Could not install GRADLE_2_4_RC_2_HOME
java.lang.NullPointerException
ERROR: Could not install GRADLE_2_4_RC_2_HOME
java.lang.NullPointerException
ERROR: Could not install GRADLE_2_4_RC_2_HOME
java.lang.NullPointerException
Build timed out (after 240 minutes). Marking the build as failed.
Build was aborted
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