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 2019/03/01 04:27:31 UTC

Build failed in Jenkins: kafka-1.0-jdk7 #263

See <https://builds.apache.org/job/kafka-1.0-jdk7/263/display/redirect?page=changes>

Changes:

[bill] KAFKA-8011: Fix for race condition causing concurrent modification

------------------------------------------
[...truncated 1.86 MB...]

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldNotAllowNullStateStoreNameWhenConnectingProcessorAndStateStores STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldNotAllowNullStateStoreNameWhenConnectingProcessorAndStateStores PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldAddTimestampExtractorPerSource STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldAddTimestampExtractorPerSource PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testPatternSourceTopic STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testPatternSourceTopic PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldAssociateStateStoreNameWhenStateStoreSupplierIsExternal STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldAssociateStateStoreNameWhenStateStoreSupplierIsExternal PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testAddSinkWithWrongParent STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testAddSinkWithWrongParent PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testPatternMatchesAlreadyProvidedTopicSource STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testPatternMatchesAlreadyProvidedTopicSource PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testAddSinkConnectedWithMultipleParent STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testAddSinkConnectedWithMultipleParent PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testSubscribeTopicNameAndPattern STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testSubscribeTopicNameAndPattern PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldAddPatternSourceWithoutOffsetReset STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldAddPatternSourceWithoutOffsetReset PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldNotAddNullInternalTopic STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldNotAddNullInternalTopic PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testAddProcessorWithWrongParent STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testAddProcessorWithWrongParent PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldNotAllowNullNameWhenAddingProcessor STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldNotAllowNullNameWhenAddingProcessor PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldAddSourcePatternWithOffsetReset STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldAddSourcePatternWithOffsetReset PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testAddStateStore STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testAddStateStore PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testAddSinkConnectedWithParent STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testAddSinkConnectedWithParent PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testAddStateStoreWithNonExistingProcessor STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > testAddStateStoreWithNonExistingProcessor PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldAddInternalTopicConfigWithCleanupPolicyDeleteForInternalTopics STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldAddInternalTopicConfigWithCleanupPolicyDeleteForInternalTopics PASSED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldCorrectlyMapStateStoreToInternalTopics STARTED

org.apache.kafka.streams.processor.internals.InternalTopologyBuilderTest > shouldCorrectlyMapStateStoreToInternalTopics PASSED

org.apache.kafka.streams.processor.internals.PartitionGroupTest > testTimeTracking STARTED

org.apache.kafka.streams.processor.internals.PartitionGroupTest > testTimeTracking PASSED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldNotFlushOffsetsWhenFlushIntervalHasNotLapsed STARTED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldNotFlushOffsetsWhenFlushIntervalHasNotLapsed PASSED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldNotFlushWhenFlushIntervalIsZero STARTED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldNotFlushWhenFlushIntervalIsZero PASSED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldUpdateStateWithReceivedRecordsForPartition STARTED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldUpdateStateWithReceivedRecordsForPartition PASSED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldSeekToInitialOffsets STARTED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldSeekToInitialOffsets PASSED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldCloseConsumer STARTED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldCloseConsumer PASSED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldFlushStoreWhenFlushIntervalHasLapsed STARTED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldFlushStoreWhenFlushIntervalHasLapsed PASSED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldUpdateStateWithReceivedRecordsForAllTopicPartition STARTED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldUpdateStateWithReceivedRecordsForAllTopicPartition PASSED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldAssignPartitionsToConsumer STARTED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldAssignPartitionsToConsumer PASSED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldCloseStateMaintainer STARTED

org.apache.kafka.streams.processor.internals.StateConsumerTest > shouldCloseStateMaintainer PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldCloseTaskAsZombieAndRemoveFromActiveTasksIfProducerGotFencedAtBeginTransactionWhenTaskIsResumed STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldCloseTaskAsZombieAndRemoveFromActiveTasksIfProducerGotFencedAtBeginTransactionWhenTaskIsResumed PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldReturnStandbyTaskMetadataWhileRunningState STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldReturnStandbyTaskMetadataWhileRunningState PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldNotNullPointerWhenStandbyTasksAssignedAndNoStateStoresForTopology STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldNotNullPointerWhenStandbyTasksAssignedAndNoStateStoresForTopology PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldInjectSharedProducerForAllTasksUsingClientSupplierOnCreateIfEosDisabled STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldInjectSharedProducerForAllTasksUsingClientSupplierOnCreateIfEosDisabled PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldCommitAfterTheCommitInterval STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldCommitAfterTheCommitInterval PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldInjectProducerPerTaskUsingClientSupplierOnCreateIfEosEnable STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldInjectProducerPerTaskUsingClientSupplierOnCreateIfEosEnable PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > testPartitionAssignmentChangeForMultipleGroups STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > testPartitionAssignmentChangeForMultipleGroups PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldNotCommitBeforeTheCommitInterval STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldNotCommitBeforeTheCommitInterval PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldNotCauseExceptionIfNothingCommited STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldNotCauseExceptionIfNothingCommited PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > testHandingOverTaskFromOneToAnotherThread STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > testHandingOverTaskFromOneToAnotherThread PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > testStateChangeStartClose STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > testStateChangeStartClose PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldCloseAllTaskProducersOnCloseIfEosEnabled STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldCloseAllTaskProducersOnCloseIfEosEnabled PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldReturnActiveTaskMetadataWhileRunningState STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldReturnActiveTaskMetadataWhileRunningState PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldShutdownTaskManagerOnClose STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldShutdownTaskManagerOnClose PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > testMetrics STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > testMetrics PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldCloseSuspendedTasksThatAreNoLongerAssignedToThisStreamThreadBeforeCreatingNewTasks STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldCloseSuspendedTasksThatAreNoLongerAssignedToThisStreamThreadBeforeCreatingNewTasks PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > testPartitionAssignmentChangeForSingleGroup STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > testPartitionAssignmentChangeForSingleGroup PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldAlwaysReturnEmptyTasksMetadataWhileRebalancingStateAndTasksNotRunning STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldAlwaysReturnEmptyTasksMetadataWhileRebalancingStateAndTasksNotRunning PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldAlwaysUpdateWithLatestTopicsFromStreamPartitionAssignor STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldAlwaysUpdateWithLatestTopicsFromStreamPartitionAssignor PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldCloseTaskAsZombieAndRemoveFromActiveTasksIfProducerWasFencedWhileProcessing STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldCloseTaskAsZombieAndRemoveFromActiveTasksIfProducerWasFencedWhileProcessing PASSED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldAlwaysUpdateTasksMetadataAfterChangingState STARTED

org.apache.kafka.streams.processor.internals.StreamThreadTest > shouldAlwaysUpdateTasksMetadataAfterChangingState PASSED

org.apache.kafka.streams.processor.internals.WrappedBatchingStateRestoreCallbackTest > shouldRestoreSinglePutsFromArray STARTED

org.apache.kafka.streams.processor.internals.WrappedBatchingStateRestoreCallbackTest > shouldRestoreSinglePutsFromArray PASSED

org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestampTest > logAndSkipOnInvalidTimestamp STARTED

org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestampTest > logAndSkipOnInvalidTimestamp PASSED

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

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

1818 tests completed, 1 failed

> Task :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-1.0-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. Run with --scan to get full insights.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 5.0.
See https://docs.gradle.org/4.8.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 45m 32s
56 actionable tasks: 31 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-1.0-jdk7/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] Parsing 5 files in <https://builds.apache.org/job/kafka-1.0-jdk7/ws/>
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/clients/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/examples/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/log4j-appender/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
No credentials specified
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=7ef21e7fab2ea8c93fce04ee6112655c561d3f71, workspace=<https://builds.apache.org/job/kafka-1.0-jdk7/ws/>
[FINDBUGS] Computing warning deltas based on reference build #262
Recording test results
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Not sending mail to unregistered user bill@confluent.io

Jenkins build is back to normal : kafka-1.0-jdk7 #265

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/kafka-1.0-jdk7/265/display/redirect?page=changes>


Build failed in Jenkins: kafka-1.0-jdk7 #264

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/kafka-1.0-jdk7/264/display/redirect?page=changes>

Changes:

[matthias] KAFKA-7855: Kafka Streams Maven Archetype quickstart fails to compile

------------------------------------------
[...truncated 1.86 MB...]

org.apache.kafka.streams.StreamsConfigTest > shouldAllowSettingConsumerIsolationLevelIfEosDisabled STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldAllowSettingConsumerIsolationLevelIfEosDisabled 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 > shouldOverrideStreamsDefaultProducerConfigs STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldOverrideStreamsDefaultProducerConfigs PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedPropertiesThatAreNotPartOfProducerConfig STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedPropertiesThatAreNotPartOfProducerConfig PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldBeBackwardsCompatibleWithDeprecatedConfigs STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldBeBackwardsCompatibleWithDeprecatedConfigs PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldBeSupportNonPrefixedConsumerConfigs STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldBeSupportNonPrefixedConsumerConfigs PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldOverrideStreamsDefaultConsumerConifgsOnRestoreConsumer STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldOverrideStreamsDefaultConsumerConifgsOnRestoreConsumer PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldAcceptExactlyOnce STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldAcceptExactlyOnce PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldSetInternalLeaveGroupOnCloseConfigToFalseInConsumer STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldSetInternalLeaveGroupOnCloseConfigToFalseInConsumer PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedPropertiesThatAreNotPartOfConsumerConfig STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedPropertiesThatAreNotPartOfConsumerConfig PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldForwardCustomConfigsWithNoPrefixToAllClients STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldForwardCustomConfigsWithNoPrefixToAllClients PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldResetToDefaultIfRestoreConsumerAutoCommitIsOverridden STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldResetToDefaultIfRestoreConsumerAutoCommitIsOverridden PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldSpecifyCorrectValueSerdeClassOnError STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldSpecifyCorrectValueSerdeClassOnError PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldSpecifyCorrectValueSerdeClassOnErrorUsingDeprecatedConfigs STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldSpecifyCorrectValueSerdeClassOnErrorUsingDeprecatedConfigs PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldResetToDefaultIfConsumerIsolationLevelIsOverriddenIfEosEnabled STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldResetToDefaultIfConsumerIsolationLevelIsOverriddenIfEosEnabled PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldNotOverrideUserConfigCommitIntervalMsIfExactlyOnceEnabled STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldNotOverrideUserConfigCommitIntervalMsIfExactlyOnceEnabled 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 > shouldThrowExceptionIfBootstrapServersIsNotSet STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldThrowExceptionIfBootstrapServersIsNotSet PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldSpecifyCorrectKeySerdeClassOnErrorUsingDeprecatedConfigs STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldSpecifyCorrectKeySerdeClassOnErrorUsingDeprecatedConfigs 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.StreamsConfigTest > shouldThrowExceptionIfApplicationIdIsNotSet STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldThrowExceptionIfApplicationIdIsNotSet PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldResetToDefaultIfProducerMaxInFlightRequestPerConnectionsIsOverriddenIfEosEnabled STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldResetToDefaultIfProducerMaxInFlightRequestPerConnectionsIsOverriddenIfEosEnabled PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldSpecifyCorrectKeySerdeClassOnError STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldSpecifyCorrectKeySerdeClassOnError PASSED

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

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

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

org.apache.kafka.streams.KafkaStreamsTest > shouldNotSetGlobalRestoreListenerAfterStarting 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 > testToString STARTED

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

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

org.apache.kafka.streams.KafkaStreamsTest > testStateCloseAfterCreate 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 > shouldCleanupOldStateDirs STARTED

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

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

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

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

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

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

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

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

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

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

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

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

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

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

org.apache.kafka.streams.KafkaStreamsTest > shouldReturnThreadMetadata 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 > testStateThreadClose STARTED

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

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

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

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

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

1818 tests completed, 1 failed

> Task :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-1.0-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. Run with --scan to get full insights.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 5.0.
See https://docs.gradle.org/4.8.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 33m 30s
56 actionable tasks: 42 executed, 14 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-1.0-jdk7/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] Parsing 5 files in <https://builds.apache.org/job/kafka-1.0-jdk7/ws/>
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/clients/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/examples/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/log4j-appender/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
No credentials specified
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=bc745af6a7a640360a092d8bbde5f68b6ad637be, workspace=<https://builds.apache.org/job/kafka-1.0-jdk7/ws/>
[FINDBUGS] Computing warning deltas based on reference build #262
Recording test results
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Not sending mail to unregistered user bill@confluent.io