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/05/17 15:54:09 UTC

Build failed in Jenkins: kafka-trunk-jdk11 #537

See <https://builds.apache.org/job/kafka-trunk-jdk11/537/display/redirect?page=changes>

Changes:

[jason] MINOR: Add test for ConsumerNetworkClient.trySend (#6739)

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on ubuntu-eu3 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk11/ws/>
[WS-CLEANUP] Deleting project workspace...
[WS-CLEANUP] Deferred wipeout is used...
No credentials specified
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-trunk-jdk11/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 64c2d49cf5c8b1cecbd7601dc2d1577fc606ab1e (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 64c2d49cf5c8b1cecbd7601dc2d1577fc606ab1e
Commit message: "MINOR: Add test for ConsumerNetworkClient.trySend (#6739)"
 > git rev-list --no-walk 8de7d3772443a63e46649ab651260db277efafec # timeout=10
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: No tool found matching GRADLE_4_10_2_HOME
[kafka-trunk-jdk11] $ /bin/bash -xe /tmp/jenkins7577635126590009775.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk11/ws/.gradle>
+ /bin/gradle
/tmp/jenkins7577635126590009775.sh: line 4: /bin/gradle: No such file or directory
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: Step ‘Publish JUnit test result report’ failed: No test report files were found. Configuration error?
ERROR: No tool found matching GRADLE_4_10_2_HOME
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Jenkins build is back to normal : kafka-trunk-jdk11 #572

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


Build failed in Jenkins: kafka-trunk-jdk11 #571

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

Changes:

[wangguoz] MINOR: Updated configuration docs with RocksDBConfigSetter#close (#6784)

------------------------------------------
[...truncated 2.61 MB...]

org.apache.kafka.connect.data.SchemaBuilderTest > testArrayBuilder STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testArrayBuilder PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testArrayBuilderInvalidDefault STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testArrayBuilderInvalidDefault PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testDuplicateFields STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testDuplicateFields PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testStringBuilderInvalidDefault STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testStringBuilderInvalidDefault PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testEmptyStruct STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testEmptyStruct PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testMapBuilderInvalidDefault STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testMapBuilderInvalidDefault PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testInt64BuilderInvalidDefault STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testInt64BuilderInvalidDefault PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testInt8Builder STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testInt8Builder PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testFieldSchemaNull STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testFieldSchemaNull PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testInt32BuilderInvalidDefault STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testInt32BuilderInvalidDefault PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testInt8BuilderInvalidDefault STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testInt8BuilderInvalidDefault PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testMapKeySchemaNull STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testMapKeySchemaNull PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testFloatBuilderInvalidDefault STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testFloatBuilderInvalidDefault PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testInt32Builder STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testInt32Builder PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testBooleanBuilder STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testBooleanBuilder PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testArraySchemaNull STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testArraySchemaNull PASSED

org.apache.kafka.connect.data.SchemaBuilderTest > testDoubleBuilder STARTED

org.apache.kafka.connect.data.SchemaBuilderTest > testDoubleBuilder PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertEmptyListToListWithoutSchema STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertEmptyListToListWithoutSchema PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertStringWithQuotesAndOtherDelimiterCharacters STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertStringWithQuotesAndOtherDelimiterCharacters PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertListWithMixedValuesToListWithoutSchema STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertListWithMixedValuesToListWithoutSchema PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertMapWithStringKeys STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertMapWithStringKeys PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldParseStringOfMapWithStringValuesWithWhitespaceAsMap STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldParseStringOfMapWithStringValuesWithWhitespaceAsMap PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertMapWithStringKeysAndShortValues STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertMapWithStringKeysAndShortValues PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldParseStringOfMapWithStringValuesWithoutWhitespaceAsMap STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldParseStringOfMapWithStringValuesWithoutWhitespaceAsMap PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertSimpleString STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertSimpleString PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertEmptyMapToMapWithoutSchema STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertEmptyMapToMapWithoutSchema PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertEmptyString STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertEmptyString PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertMapWithStringKeysAndMixedValuesToMapWithoutSchema STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertMapWithStringKeysAndMixedValuesToMapWithoutSchema PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldParseStringOfMapWithIntValuesWithoutWhitespaceAsMap STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldParseStringOfMapWithIntValuesWithoutWhitespaceAsMap PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldParseStringOfMapWithShortValuesWithWhitespaceAsMap STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldParseStringOfMapWithShortValuesWithWhitespaceAsMap PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertMapWithStringKeysAndIntegerValues STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertMapWithStringKeysAndIntegerValues PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertNullValue STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertNullValue PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldParseStringOfMapWithShortValuesWithoutWhitespaceAsMap STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldParseStringOfMapWithShortValuesWithoutWhitespaceAsMap PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertListWithStringValues STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertListWithStringValues PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldParseStringOfMapWithIntValuesWithWhitespaceAsMap STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldParseStringOfMapWithIntValuesWithWhitespaceAsMap PASSED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertListWithIntegerValues STARTED

org.apache.kafka.connect.storage.SimpleHeaderConverterTest > shouldConvertListWithIntegerValues PASSED

org.apache.kafka.connect.storage.ConverterTypeTest > shouldFindByName STARTED

org.apache.kafka.connect.storage.ConverterTypeTest > shouldFindByName PASSED

org.apache.kafka.connect.storage.StringConverterTest > testBytesNullToString STARTED

org.apache.kafka.connect.storage.StringConverterTest > testBytesNullToString PASSED

org.apache.kafka.connect.storage.StringConverterTest > testToBytesNonUtf8Encoding STARTED

org.apache.kafka.connect.storage.StringConverterTest > testToBytesNonUtf8Encoding PASSED

org.apache.kafka.connect.storage.StringConverterTest > testNonStringToBytes STARTED

org.apache.kafka.connect.storage.StringConverterTest > testNonStringToBytes PASSED

org.apache.kafka.connect.storage.StringConverterTest > testBytesToStringNonUtf8Encoding STARTED

org.apache.kafka.connect.storage.StringConverterTest > testBytesToStringNonUtf8Encoding PASSED

org.apache.kafka.connect.storage.StringConverterTest > testNullToBytes STARTED

org.apache.kafka.connect.storage.StringConverterTest > testNullToBytes PASSED

org.apache.kafka.connect.storage.StringConverterTest > testNullHeaderValueToBytes STARTED

org.apache.kafka.connect.storage.StringConverterTest > testNullHeaderValueToBytes PASSED

org.apache.kafka.connect.storage.StringConverterTest > testStringHeaderValueToBytes STARTED

org.apache.kafka.connect.storage.StringConverterTest > testStringHeaderValueToBytes PASSED

org.apache.kafka.connect.storage.StringConverterTest > testToBytesIgnoresSchema STARTED

org.apache.kafka.connect.storage.StringConverterTest > testToBytesIgnoresSchema PASSED

org.apache.kafka.connect.storage.StringConverterTest > testNonStringHeaderValueToBytes STARTED

org.apache.kafka.connect.storage.StringConverterTest > testNonStringHeaderValueToBytes PASSED

org.apache.kafka.connect.storage.StringConverterTest > testStringToBytes STARTED

org.apache.kafka.connect.storage.StringConverterTest > testStringToBytes PASSED

org.apache.kafka.connect.storage.StringConverterTest > testBytesToString STARTED

org.apache.kafka.connect.storage.StringConverterTest > testBytesToString PASSED

org.apache.kafka.connect.util.ConnectorUtilsTest > testGroupPartitions STARTED

org.apache.kafka.connect.util.ConnectorUtilsTest > testGroupPartitions PASSED

org.apache.kafka.connect.util.ConnectorUtilsTest > testGroupPartitionsInvalidCount STARTED

org.apache.kafka.connect.util.ConnectorUtilsTest > testGroupPartitionsInvalidCount PASSED

org.apache.kafka.connect.connector.ConnectorReconfigurationTest > testReconfigureStopException STARTED

org.apache.kafka.connect.connector.ConnectorReconfigurationTest > testReconfigureStopException PASSED

org.apache.kafka.connect.connector.ConnectorReconfigurationTest > testDefaultReconfigure STARTED

org.apache.kafka.connect.connector.ConnectorReconfigurationTest > testDefaultReconfigure PASSED

FAILURE: Build completed with 2 failures.

1: Task 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-jdk11/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.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 3h 3m 48s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #570

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

Changes:

[github] MINOR: fix Streams version-probing system test (#6764)

------------------------------------------
[...truncated 2.48 MB...]
org.apache.kafka.connect.source.SourceRecordTest > shouldDuplicateRecordUsingNewHeaders STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldDuplicateRecordUsingNewHeaders PASSED

org.apache.kafka.connect.source.SourceRecordTest > shouldModifyRecordHeader STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldModifyRecordHeader PASSED

org.apache.kafka.connect.source.SourceRecordTest > shouldCreateSinkRecordWithHeaders STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldCreateSinkRecordWithHeaders PASSED

org.apache.kafka.connect.source.SourceRecordTest > shouldCreateSinkRecordWithEmtpyHeaders STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldCreateSinkRecordWithEmtpyHeaders PASSED

org.apache.kafka.connect.sink.SinkRecordTest > shouldDuplicateRecordAndCloneHeaders STARTED

org.apache.kafka.connect.sink.SinkRecordTest > shouldDuplicateRecordAndCloneHeaders PASSED

org.apache.kafka.connect.sink.SinkRecordTest > shouldCreateSinkRecordWithEmptyHeaders STARTED

org.apache.kafka.connect.sink.SinkRecordTest > shouldCreateSinkRecordWithEmptyHeaders PASSED

org.apache.kafka.connect.sink.SinkRecordTest > shouldDuplicateRecordUsingNewHeaders STARTED

org.apache.kafka.connect.sink.SinkRecordTest > shouldDuplicateRecordUsingNewHeaders PASSED

org.apache.kafka.connect.sink.SinkRecordTest > shouldModifyRecordHeader STARTED

org.apache.kafka.connect.sink.SinkRecordTest > shouldModifyRecordHeader PASSED

org.apache.kafka.connect.sink.SinkRecordTest > shouldCreateSinkRecordWithHeaders STARTED

org.apache.kafka.connect.sink.SinkRecordTest > shouldCreateSinkRecordWithHeaders PASSED

> Task :streams:streams-scala:test

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegionWithNamedRepartitionTopic STARTED

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegionWithNamedRepartitionTopic PASSED

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegionJava STARTED

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegionJava PASSED

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegion STARTED

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegion PASSED

org.apache.kafka.streams.scala.kstream.SuppressedTest > Suppressed.untilWindowCloses should produce the correct suppression STARTED

org.apache.kafka.streams.scala.kstream.SuppressedTest > Suppressed.untilWindowCloses should produce the correct suppression PASSED

org.apache.kafka.streams.scala.kstream.SuppressedTest > Suppressed.untilTimeLimit should produce the correct suppression STARTED

org.apache.kafka.streams.scala.kstream.SuppressedTest > Suppressed.untilTimeLimit should produce the correct suppression PASSED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig.maxRecords should produce the correct buffer config STARTED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig.maxRecords should produce the correct buffer config PASSED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig.maxBytes should produce the correct buffer config STARTED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig.maxBytes should produce the correct buffer config PASSED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig.unbounded should produce the correct buffer config STARTED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig.unbounded should produce the correct buffer config PASSED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig should support very long chains of factory methods STARTED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig should support very long chains of factory methods PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed should create a Consumed with Serdes STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed should create a Consumed with Serdes PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor should create a Consumed with Serdes and timestampExtractor STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor should create a Consumed with Serdes and timestampExtractor PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with resetPolicy should create a Consumed with Serdes and resetPolicy STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with resetPolicy should create a Consumed with Serdes and resetPolicy PASSED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced should create a Produced with Serdes STARTED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced should create a Produced with Serdes PASSED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy STARTED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy PASSED

org.apache.kafka.streams.scala.kstream.GroupedTest > Create a Grouped should create a Grouped with Serdes STARTED

org.apache.kafka.streams.scala.kstream.GroupedTest > Create a Grouped should create a Grouped with Serdes PASSED

org.apache.kafka.streams.scala.kstream.GroupedTest > Create a Grouped with repartition topic name should create a Grouped with Serdes, and repartition topic name STARTED

org.apache.kafka.streams.scala.kstream.GroupedTest > Create a Grouped with repartition topic name should create a Grouped with Serdes, and repartition topic name PASSED

org.apache.kafka.streams.scala.kstream.JoinedTest > Create a Joined should create a Joined with Serdes STARTED

org.apache.kafka.streams.scala.kstream.JoinedTest > Create a Joined should create a Joined with Serdes PASSED

org.apache.kafka.streams.scala.kstream.JoinedTest > Create a Joined should create a Joined with Serdes and repartition topic name STARTED

org.apache.kafka.streams.scala.kstream.JoinedTest > Create a Joined should create a Joined with Serdes and repartition topic name PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > filter a KTable should filter records satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > filter a KTable should filter records satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > filterNot a KTable should filter records not satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > filterNot a KTable should filter records not satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables should join correctly records STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables should join correctly records PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables with a Materialized should join correctly records and state store STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables with a Materialized should join correctly records and state store PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > windowed KTable#suppress should correctly suppress results using Suppressed.untilTimeLimit STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > windowed KTable#suppress should correctly suppress results using Suppressed.untilTimeLimit PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > windowed KTable#suppress should correctly suppress results using Suppressed.untilWindowCloses STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > windowed KTable#suppress should correctly suppress results using Suppressed.untilWindowCloses PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > session windowed KTable#suppress should correctly suppress results using Suppressed.untilWindowCloses STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > session windowed KTable#suppress should correctly suppress results using Suppressed.untilWindowCloses PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > non-windowed KTable#suppress should correctly suppress results using Suppressed.untilTimeLimit STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > non-windowed KTable#suppress should correctly suppress results using Suppressed.untilTimeLimit PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialized should create a Materialized with Serdes STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialized should create a Materialized with Serdes PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a store name should create a Materialized with Serdes and a store name STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a store name should create a Materialized with Serdes and a store name PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a window store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a window store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a key value store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a key value store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a session store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a session store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > filter a KStream should filter records satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > filter a KStream should filter records satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > filterNot a KStream should filter records not satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > filterNot a KStream should filter records not satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > foreach a KStream should run foreach actions on records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > foreach a KStream should run foreach actions on records PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > peek a KStream should run peek actions on records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > peek a KStream should run peek actions on records PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > selectKey a KStream should select a new key STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > selectKey a KStream should select a new key PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > join 2 KStreams should join correctly records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > join 2 KStreams should join correctly records PASSED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsMaterialized STARTED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsMaterialized PASSED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsJava STARTED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsJava PASSED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWords STARTED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWords PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaJoin STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaJoin PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaSimple STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaSimple PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaAggregate STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaAggregate PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaProperties STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaProperties PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaTransform STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaTransform PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 49m 7s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #569

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

Changes:

[jason] MINOR: Fix a few compiler warnings (#6767)

------------------------------------------
[...truncated 2.49 MB...]
org.apache.kafka.connect.json.JsonConverterTest > testJsonSchemaMetadataTranslation STARTED

org.apache.kafka.connect.json.JsonConverterTest > testJsonSchemaMetadataTranslation PASSED

org.apache.kafka.connect.json.JsonConverterTest > bytesToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > bytesToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > shortToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > shortToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > intToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > intToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndNullValueToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndNullValueToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > structToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > structToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > stringToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > stringToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndArrayToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndArrayToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > byteToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > byteToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaPrimitiveToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaPrimitiveToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > byteToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > byteToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > intToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > intToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndPrimitiveToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndPrimitiveToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > arrayToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > arrayToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > structToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > structToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > testConnectSchemaMetadataTranslation STARTED

org.apache.kafka.connect.json.JsonConverterTest > testConnectSchemaMetadataTranslation PASSED

org.apache.kafka.connect.json.JsonConverterTest > shortToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > shortToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > doubleToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > doubleToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > testStringHeaderToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > testStringHeaderToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > structSchemaIdentical STARTED

org.apache.kafka.connect.json.JsonConverterTest > structSchemaIdentical PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > floatToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > floatToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > arrayToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > arrayToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > testCacheSchemaToConnectConversion STARTED

org.apache.kafka.connect.json.JsonConverterTest > testCacheSchemaToConnectConversion PASSED

org.apache.kafka.connect.json.JsonConverterTest > booleanToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > booleanToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > bytesToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > bytesToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > doubleToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > doubleToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptionalWithDefaultValue PASSED

> Task :log4j-appender:test

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithSyncSendWithoutIgnoringExceptionsShouldNotThrowException STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithSyncSendWithoutIgnoringExceptionsShouldNotThrowException PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithRealProducerConfigWithSyncSendAndNotIgnoringExceptionsShouldThrowException STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithRealProducerConfigWithSyncSendAndNotIgnoringExceptionsShouldThrowException PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppends STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppends PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSetSaslMechanism STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSetSaslMechanism PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testJaasConfigNotSet STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testJaasConfigNotSet PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testKafkaLog4jConfigs STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testKafkaLog4jConfigs PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithSyncSendAndSimulateProducerFailShouldThrowException STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithSyncSendAndSimulateProducerFailShouldThrowException PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithRealProducerConfigWithSyncSendShouldNotThrowException STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithRealProducerConfigWithSyncSendShouldNotThrowException PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSaslMechanismNotSet STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSaslMechanismNotSet PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSetJaasConfig STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSetJaasConfig PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 34m 53s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #568

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

Changes:

[github] MINOR: add Kafka Streams upgrade notes for 2.3 release (#6758)

------------------------------------------
[...truncated 2.48 MB...]
org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldListenForRestoreEvents STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldListenForRestoreEvents 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 > shouldRetryWhenPartitionsForThrowsTimeoutException STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldRetryWhenPartitionsForThrowsTimeoutException 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 > shouldDeleteAndRecreateStoreDirectoryOnReinitialize STARTED

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

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

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldNotDeleteCheckpointFileAfterLoaded 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 > shouldSkipNullKeysWhenRestoring STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldSkipNullKeysWhenRestoring 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 > shouldCheckpointRestoredOffsetsToFile STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldCheckpointRestoredOffsetsToFile 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 > shouldCheckpointOffsets STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldCheckpointOffsets 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 > shouldSkipGlobalInMemoryStoreOffsetsToFile STARTED

org.apache.kafka.streams.processor.internals.GlobalStateManagerImplTest > shouldSkipGlobalInMemoryStoreOffsetsToFile 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 > shouldConvertValuesIfStoreImplementsTimestampedBytesStore STARTED

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

org.apache.kafka.streams.processor.internals.RecordQueueTest > shouldDropOnNegativeTimestamp STARTED

org.apache.kafka.streams.processor.internals.RecordQueueTest > shouldDropOnNegativeTimestamp PASSED

org.apache.kafka.streams.processor.internals.RecordQueueTest > shouldNotThrowStreamsExceptionWhenValueDeserializationFailsWithSkipHandler STARTED

org.apache.kafka.streams.processor.internals.RecordQueueTest > shouldNotThrowStreamsExceptionWhenValueDeserializationFailsWithSkipHandler PASSED

org.apache.kafka.streams.processor.internals.RecordQueueTest > shouldThrowOnNegativeTimestamp STARTED

org.apache.kafka.streams.processor.internals.RecordQueueTest > shouldThrowOnNegativeTimestamp PASSED

org.apache.kafka.streams.processor.internals.RecordQueueTest > shouldThrowStreamsExceptionWhenKeyDeserializationFails STARTED

org.apache.kafka.streams.processor.internals.RecordQueueTest > shouldThrowStreamsExceptionWhenKeyDeserializationFails PASSED

org.apache.kafka.streams.processor.internals.RecordQueueTest > shouldThrowStreamsExceptionWhenValueDeserializationFails STARTED

org.apache.kafka.streams.processor.internals.RecordQueueTest > shouldThrowStreamsExceptionWhenValueDeserializationFails PASSED

org.apache.kafka.streams.processor.internals.RecordQueueTest > shouldNotThrowStreamsExceptionWhenKeyDeserializationFailsWithSkipHandler STARTED

org.apache.kafka.streams.processor.internals.RecordQueueTest > shouldNotThrowStreamsExceptionWhenKeyDeserializationFailsWithSkipHandler PASSED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testMutiLevelSensorRemoval STARTED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testMutiLevelSensorRemoval PASSED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testThroughputMetrics STARTED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testThroughputMetrics PASSED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testTotalMetricDoesntDecrease STARTED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testTotalMetricDoesntDecrease PASSED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testLatencyMetrics STARTED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testLatencyMetrics PASSED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testRemoveSensor STARTED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testRemoveSensor PASSED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testRemoveNullSensor STARTED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testRemoveNullSensor PASSED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testNullMetrics STARTED

org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImplTest > testNullMetrics PASSED

org.apache.kafka.streams.processor.internals.ProcessorNodeTest > shouldThrowStreamsExceptionIfExceptionCaughtDuringInit STARTED

org.apache.kafka.streams.processor.internals.ProcessorNodeTest > shouldThrowStreamsExceptionIfExceptionCaughtDuringInit PASSED

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

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

org.apache.kafka.streams.processor.internals.ProcessorNodeTest > shouldThrowStreamsExceptionIfExceptionCaughtDuringClose STARTED

org.apache.kafka.streams.processor.internals.ProcessorNodeTest > shouldThrowStreamsExceptionIfExceptionCaughtDuringClose PASSED

org.apache.kafka.streams.processor.DefaultPartitionGrouperTest > shouldComputeGroupingForSingleGroupWithMultipleTopics STARTED

org.apache.kafka.streams.processor.DefaultPartitionGrouperTest > shouldComputeGroupingForSingleGroupWithMultipleTopics PASSED

org.apache.kafka.streams.processor.DefaultPartitionGrouperTest > shouldNotCreateAnyTasksBecauseOneTopicHasUnknownPartitions STARTED

org.apache.kafka.streams.processor.DefaultPartitionGrouperTest > shouldNotCreateAnyTasksBecauseOneTopicHasUnknownPartitions PASSED

org.apache.kafka.streams.processor.DefaultPartitionGrouperTest > shouldComputeGroupingForTwoGroups STARTED

org.apache.kafka.streams.processor.DefaultPartitionGrouperTest > shouldComputeGroupingForTwoGroups PASSED

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

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

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

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

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

org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestampTest > extractMetadataTimestamp 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
streams-9: SMOKE-TEST-CLIENT-CLOSED
streams-8: SMOKE-TEST-CLIENT-CLOSED
streams-6: SMOKE-TEST-CLIENT-CLOSED
streams-1: SMOKE-TEST-CLIENT-CLOSED
streams-0: SMOKE-TEST-CLIENT-CLOSED
streams-3: SMOKE-TEST-CLIENT-CLOSED
streams-5: SMOKE-TEST-CLIENT-CLOSED
streams-4: SMOKE-TEST-CLIENT-CLOSED
streams-2: SMOKE-TEST-CLIENT-CLOSED
streams-7: SMOKE-TEST-CLIENT-CLOSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 37m 34s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #567

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

Changes:

[github] MINOR: Update jackson to 2.9.9 (#6798)

------------------------------------------
[...truncated 2.68 MB...]
org.apache.kafka.connect.transforms.CastTest > testConfigInvalidMap PASSED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordValueWithSchemaBooleanTrue STARTED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordValueWithSchemaBooleanTrue PASSED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordDefaultValue STARTED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordDefaultValue PASSED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordValueWithSchemaInt8 STARTED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordValueWithSchemaInt8 PASSED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordKeyWithSchema STARTED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordKeyWithSchema PASSED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordValueSchemalessInt8 STARTED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordValueSchemalessInt8 PASSED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordValueSchemalessBooleanFalse STARTED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordValueSchemalessBooleanFalse PASSED

org.apache.kafka.connect.transforms.CastTest > testConfigInvalidSchemaType STARTED

org.apache.kafka.connect.transforms.CastTest > testConfigInvalidSchemaType PASSED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordValueSchemalessString STARTED

org.apache.kafka.connect.transforms.CastTest > castWholeRecordValueSchemalessString PASSED

org.apache.kafka.connect.transforms.CastTest > castFieldsWithSchema STARTED

org.apache.kafka.connect.transforms.CastTest > castFieldsWithSchema PASSED

org.apache.kafka.connect.transforms.HoistFieldTest > withSchema STARTED

org.apache.kafka.connect.transforms.HoistFieldTest > withSchema PASSED

org.apache.kafka.connect.transforms.HoistFieldTest > schemaless STARTED

org.apache.kafka.connect.transforms.HoistFieldTest > schemaless PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessFieldConversion STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessFieldConversion PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidTargetType STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidTargetType PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessStringToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessStringToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testKey STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testKey PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessDateToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessDateToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimeToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimeToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaUnixToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaUnixToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessIdentity STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessIdentity PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaFieldConversion STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaFieldConversion PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaDateToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaDateToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaIdentity STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaIdentity PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigMissingFormat STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigMissingFormat PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigNoTargetType STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigNoTargetType PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaStringToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaStringToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimeToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimeToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessUnixToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessUnixToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidFormat STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidFormat PASSED

org.apache.kafka.connect.transforms.ReplaceFieldTest > withSchema STARTED

org.apache.kafka.connect.transforms.ReplaceFieldTest > withSchema PASSED

org.apache.kafka.connect.transforms.ReplaceFieldTest > schemaless STARTED

org.apache.kafka.connect.transforms.ReplaceFieldTest > schemaless PASSED

org.apache.kafka.connect.transforms.ExtractFieldTest > withSchema STARTED

org.apache.kafka.connect.transforms.ExtractFieldTest > withSchema PASSED

org.apache.kafka.connect.transforms.ExtractFieldTest > testNullWithSchema STARTED

org.apache.kafka.connect.transforms.ExtractFieldTest > testNullWithSchema PASSED

org.apache.kafka.connect.transforms.ExtractFieldTest > schemaless STARTED

org.apache.kafka.connect.transforms.ExtractFieldTest > schemaless PASSED

org.apache.kafka.connect.transforms.ExtractFieldTest > testNullSchemaless STARTED

org.apache.kafka.connect.transforms.ExtractFieldTest > testNullSchemaless PASSED

org.apache.kafka.connect.transforms.ValueToKeyTest > withSchema STARTED

org.apache.kafka.connect.transforms.ValueToKeyTest > withSchema PASSED

org.apache.kafka.connect.transforms.ValueToKeyTest > schemaless STARTED

org.apache.kafka.connect.transforms.ValueToKeyTest > schemaless PASSED

org.apache.kafka.connect.transforms.TimestampRouterTest > defaultConfiguration STARTED

org.apache.kafka.connect.transforms.TimestampRouterTest > defaultConfiguration PASSED

org.apache.kafka.connect.transforms.InsertFieldTest > schemalessInsertConfiguredFields STARTED

org.apache.kafka.connect.transforms.InsertFieldTest > schemalessInsertConfiguredFields PASSED

org.apache.kafka.connect.transforms.InsertFieldTest > topLevelStructRequired STARTED

org.apache.kafka.connect.transforms.InsertFieldTest > topLevelStructRequired PASSED

org.apache.kafka.connect.transforms.InsertFieldTest > copySchemaAndInsertConfiguredFields STARTED

org.apache.kafka.connect.transforms.InsertFieldTest > copySchemaAndInsertConfiguredFields PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameUpdate STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameUpdate PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameAndVersionUpdateWithStruct STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameAndVersionUpdateWithStruct PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfStruct STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfStruct PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameAndVersionUpdate STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameAndVersionUpdate PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfNull STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfNull PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaVersionUpdate STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaVersionUpdate PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfNonStruct STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfNonStruct PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 51m 59s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #566

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

Changes:

[github] KAFKA-8371: Remove dependence on ReplicaManager from Partition (#6705)

[cshapi] MINOR: Add 2.0, 2.1 and 2.2 to broker and client compat tests

------------------------------------------
[...truncated 2.47 MB...]
org.apache.kafka.connect.json.JsonConverterTest > timestampToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullValueToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullValueToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > stringHeaderToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > stringHeaderToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonNonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonNonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > longToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > longToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > mismatchSchemaJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > mismatchSchemaJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectNonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectNonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > testJsonSchemaMetadataTranslation STARTED

org.apache.kafka.connect.json.JsonConverterTest > testJsonSchemaMetadataTranslation PASSED

org.apache.kafka.connect.json.JsonConverterTest > bytesToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > bytesToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > shortToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > shortToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > intToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > intToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndNullValueToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndNullValueToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > structToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > structToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > stringToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > stringToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndArrayToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndArrayToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > byteToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > byteToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaPrimitiveToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaPrimitiveToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > byteToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > byteToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > intToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > intToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndPrimitiveToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndPrimitiveToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > arrayToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > arrayToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > structToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > structToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > testConnectSchemaMetadataTranslation STARTED

org.apache.kafka.connect.json.JsonConverterTest > testConnectSchemaMetadataTranslation PASSED

org.apache.kafka.connect.json.JsonConverterTest > shortToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > shortToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > doubleToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > doubleToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > testStringHeaderToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > testStringHeaderToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > structSchemaIdentical STARTED

org.apache.kafka.connect.json.JsonConverterTest > structSchemaIdentical PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > floatToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > floatToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > arrayToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > arrayToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > testCacheSchemaToConnectConversion STARTED

org.apache.kafka.connect.json.JsonConverterTest > testCacheSchemaToConnectConversion PASSED

org.apache.kafka.connect.json.JsonConverterTest > booleanToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > booleanToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > bytesToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > bytesToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > doubleToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > doubleToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptionalWithDefaultValue PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 57m 25s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #565

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

Changes:

[github] MINOR: Remove checking on original joined subscription within

[cmccabe] KAFKA-8417: Remove redundant network definition --net=host when starting

[rhauch] KAFKA-8415: Interface ConnectorClientConfigOverridePolicy needs to be

[rhauch] KAFKA-8407: Fix validation of class and list configs in connector client

------------------------------------------
[...truncated 2.47 MB...]
org.apache.kafka.connect.json.JsonConverterTest > timestampToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullValueToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullValueToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > stringHeaderToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > stringHeaderToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonNonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonNonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > longToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > longToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > mismatchSchemaJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > mismatchSchemaJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectNonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectNonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > testJsonSchemaMetadataTranslation STARTED

org.apache.kafka.connect.json.JsonConverterTest > testJsonSchemaMetadataTranslation PASSED

org.apache.kafka.connect.json.JsonConverterTest > bytesToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > bytesToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > shortToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > shortToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > intToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > intToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndNullValueToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndNullValueToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > structToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > structToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > stringToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > stringToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndArrayToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndArrayToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > byteToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > byteToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaPrimitiveToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaPrimitiveToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > byteToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > byteToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > intToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > intToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndPrimitiveToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndPrimitiveToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > arrayToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > arrayToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > structToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > structToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > testConnectSchemaMetadataTranslation STARTED

org.apache.kafka.connect.json.JsonConverterTest > testConnectSchemaMetadataTranslation PASSED

org.apache.kafka.connect.json.JsonConverterTest > shortToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > shortToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > doubleToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > doubleToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > testStringHeaderToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > testStringHeaderToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > structSchemaIdentical STARTED

org.apache.kafka.connect.json.JsonConverterTest > structSchemaIdentical PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > floatToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > floatToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > arrayToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > arrayToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > testCacheSchemaToConnectConversion STARTED

org.apache.kafka.connect.json.JsonConverterTest > testCacheSchemaToConnectConversion PASSED

org.apache.kafka.connect.json.JsonConverterTest > booleanToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > booleanToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > bytesToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > bytesToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > doubleToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > doubleToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptionalWithDefaultValue PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 52m 12s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #564

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

Changes:

[jason] KAFKA-8229; Reset WorkerSinkTask offset commit interval after task

------------------------------------------
[...truncated 2.46 MB...]
org.apache.kafka.connect.json.JsonConverterTest > timestampToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullValueToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullValueToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > stringHeaderToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > stringHeaderToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonNonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonNonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > longToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > longToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > mismatchSchemaJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > mismatchSchemaJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectNonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectNonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > testJsonSchemaMetadataTranslation STARTED

org.apache.kafka.connect.json.JsonConverterTest > testJsonSchemaMetadataTranslation PASSED

org.apache.kafka.connect.json.JsonConverterTest > bytesToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > bytesToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > shortToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > shortToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > intToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > intToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndNullValueToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndNullValueToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > structToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > structToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > stringToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > stringToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndArrayToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndArrayToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > byteToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > byteToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaPrimitiveToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaPrimitiveToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > byteToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > byteToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > intToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > intToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndPrimitiveToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndPrimitiveToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > arrayToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > arrayToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > structToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > structToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > testConnectSchemaMetadataTranslation STARTED

org.apache.kafka.connect.json.JsonConverterTest > testConnectSchemaMetadataTranslation PASSED

org.apache.kafka.connect.json.JsonConverterTest > shortToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > shortToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > doubleToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > doubleToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > testStringHeaderToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > testStringHeaderToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > structSchemaIdentical STARTED

org.apache.kafka.connect.json.JsonConverterTest > structSchemaIdentical PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > floatToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > floatToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > arrayToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > arrayToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > testCacheSchemaToConnectConversion STARTED

org.apache.kafka.connect.json.JsonConverterTest > testCacheSchemaToConnectConversion PASSED

org.apache.kafka.connect.json.JsonConverterTest > booleanToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > booleanToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > bytesToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > bytesToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > doubleToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > doubleToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptionalWithDefaultValue PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 40m 17s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #563

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

Changes:

[github] MINOR: Remove ControllerEventManager metrics on close (#6788)

------------------------------------------
[...truncated 2.51 MB...]
org.apache.kafka.connect.json.JsonConverterTest > timestampToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullValueToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullValueToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > stringHeaderToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > stringHeaderToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonNonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonNonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > longToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > longToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > mismatchSchemaJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > mismatchSchemaJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectNonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectNonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > testJsonSchemaMetadataTranslation STARTED

org.apache.kafka.connect.json.JsonConverterTest > testJsonSchemaMetadataTranslation PASSED

org.apache.kafka.connect.json.JsonConverterTest > bytesToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > bytesToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > shortToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > shortToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > intToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > intToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndNullValueToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndNullValueToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > structToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > structToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > stringToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > stringToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndArrayToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndArrayToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > byteToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > byteToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaPrimitiveToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaPrimitiveToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > byteToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > byteToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > intToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > intToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndPrimitiveToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndPrimitiveToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > arrayToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > arrayToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > structToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > structToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > testConnectSchemaMetadataTranslation STARTED

org.apache.kafka.connect.json.JsonConverterTest > testConnectSchemaMetadataTranslation PASSED

org.apache.kafka.connect.json.JsonConverterTest > shortToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > shortToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > doubleToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > doubleToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > testStringHeaderToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > testStringHeaderToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > structSchemaIdentical STARTED

org.apache.kafka.connect.json.JsonConverterTest > structSchemaIdentical PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > floatToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > floatToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > arrayToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > arrayToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > testCacheSchemaToConnectConversion STARTED

org.apache.kafka.connect.json.JsonConverterTest > testCacheSchemaToConnectConversion PASSED

org.apache.kafka.connect.json.JsonConverterTest > booleanToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > booleanToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > bytesToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > bytesToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > doubleToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > doubleToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptionalWithDefaultValue PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 47m 58s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #562

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/kafka-trunk-jdk11/562/display/redirect>

------------------------------------------
[...truncated 2.47 MB...]
org.apache.kafka.streams.TopologyTestDriverTest > shouldProcessRecordForTopic[Eos enabled = true] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldForwardRecordsFromSubtopologyToSubtopology[Eos enabled = true] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldForwardRecordsFromSubtopologyToSubtopology[Eos enabled = true] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldNotUpdateStoreForSmallerValue[Eos enabled = true] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldNotUpdateStoreForSmallerValue[Eos enabled = true] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldCreateStateDirectoryForStatefulTopology[Eos enabled = true] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldCreateStateDirectoryForStatefulTopology[Eos enabled = true] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldPunctuateIfWallClockTimeAdvances[Eos enabled = true] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldPunctuateIfWallClockTimeAdvances[Eos enabled = true] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldCloseProcessor[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldCloseProcessor[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldFeedStoreFromGlobalKTable[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldFeedStoreFromGlobalKTable[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldCleanUpPersistentStateStoresOnClose[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldCleanUpPersistentStateStoresOnClose[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldThrowPatternNotValidForTopicNameException[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldThrowPatternNotValidForTopicNameException[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldPunctuateIfEvenTimeAdvances[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldPunctuateIfEvenTimeAdvances[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldInitProcessor[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldInitProcessor[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldThrowForUnknownTopic[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldThrowForUnknownTopic[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldPunctuateOnStreamsTime[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldPunctuateOnStreamsTime[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldThrowIfInMemoryBuiltInStoreIsAccessedWithUntypedMethod[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldThrowIfInMemoryBuiltInStoreIsAccessedWithUntypedMethod[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldProcessFromSourcesThatMatchMultiplePattern[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldProcessFromSourcesThatMatchMultiplePattern[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldPopulateGlobalStore[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldPopulateGlobalStore[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldThrowIfPersistentBuiltInStoreIsAccessedWithUntypedMethod[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldThrowIfPersistentBuiltInStoreIsAccessedWithUntypedMethod[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldAllowPrePopulatingStatesStoresWithCachingEnabled[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldAllowPrePopulatingStatesStoresWithCachingEnabled[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldReturnCorrectPersistentStoreTypeOnly[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldReturnCorrectPersistentStoreTypeOnly[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldUseSourceSpecificDeserializers[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldUseSourceSpecificDeserializers[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldReturnAllStores[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldReturnAllStores[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldSendRecordViaCorrectSourceTopic[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldSendRecordViaCorrectSourceTopic[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldNotCreateStateDirectoryForStatelessTopology[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldNotCreateStateDirectoryForStatelessTopology[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldReturnAllStoresNames[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldReturnAllStoresNames[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldProcessConsumerRecordList[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldProcessConsumerRecordList[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldUseSinkSpecificSerializers[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldUseSinkSpecificSerializers[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldFlushStoreForFirstInput[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldFlushStoreForFirstInput[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldProcessFromSourceThatMatchPattern[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldProcessFromSourceThatMatchPattern[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldUpdateStoreForNewKey[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldUpdateStoreForNewKey[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldPunctuateOnWallClockTime[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldPunctuateOnWallClockTime[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldSetRecordMetadata[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldSetRecordMetadata[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldNotUpdateStoreForLargerValue[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldNotUpdateStoreForLargerValue[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldReturnCorrectInMemoryStoreTypeOnly[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldReturnCorrectInMemoryStoreTypeOnly[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldProcessRecordForTopic[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldProcessRecordForTopic[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldForwardRecordsFromSubtopologyToSubtopology[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldForwardRecordsFromSubtopologyToSubtopology[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldNotUpdateStoreForSmallerValue[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldNotUpdateStoreForSmallerValue[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldCreateStateDirectoryForStatefulTopology[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldCreateStateDirectoryForStatefulTopology[Eos enabled = false] PASSED

org.apache.kafka.streams.TopologyTestDriverTest > shouldPunctuateIfWallClockTimeAdvances[Eos enabled = false] STARTED

org.apache.kafka.streams.TopologyTestDriverTest > shouldPunctuateIfWallClockTimeAdvances[Eos enabled = false] PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldReturnIsOpen STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldReturnIsOpen PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldDeleteAndReturnPlainValue STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldDeleteAndReturnPlainValue PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldReturnName STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldReturnName PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldPutWithUnknownTimestamp STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldPutWithUnknownTimestamp PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldPutAllWithUnknownTimestamp STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldPutAllWithUnknownTimestamp PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldReturnIsPersistent STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldReturnIsPersistent PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldPutIfAbsentWithUnknownTimestamp STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldPutIfAbsentWithUnknownTimestamp PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldForwardClose STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldForwardClose PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldForwardFlush STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldForwardFlush PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldForwardInit STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldForwardInit PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldReturnIsOpen STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldReturnIsOpen PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldReturnName STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldReturnName PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldPutWithUnknownTimestamp STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldPutWithUnknownTimestamp PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldPutWindowStartTimestampWithUnknownTimestamp STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldPutWindowStartTimestampWithUnknownTimestamp PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldReturnIsPersistent STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldReturnIsPersistent PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldForwardClose STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldForwardClose PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldForwardFlush STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldForwardFlush PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldForwardInit STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldForwardInit PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 37m 32s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #561

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

Changes:

[bbejeck] KAFKA-8399: bring back internal.leave.group.on.close config for KStream

------------------------------------------
[...truncated 2.44 MB...]

org.apache.kafka.connect.data.ValuesTest > shouldFailToConvertToListFromStringWithNonCommonElementTypeAndBlankElement PASSED

org.apache.kafka.connect.data.ValuesTest > shouldParseStringsWithMultipleDelimiters STARTED

org.apache.kafka.connect.data.ValuesTest > shouldParseStringsWithMultipleDelimiters PASSED

org.apache.kafka.connect.data.DateTest > testFromLogicalInvalidHasTimeComponents STARTED

org.apache.kafka.connect.data.DateTest > testFromLogicalInvalidHasTimeComponents PASSED

org.apache.kafka.connect.data.DateTest > testFromLogicalInvalidSchema STARTED

org.apache.kafka.connect.data.DateTest > testFromLogicalInvalidSchema PASSED

org.apache.kafka.connect.data.DateTest > testToLogical STARTED

org.apache.kafka.connect.data.DateTest > testToLogical PASSED

org.apache.kafka.connect.data.DateTest > testFromLogical STARTED

org.apache.kafka.connect.data.DateTest > testFromLogical PASSED

org.apache.kafka.connect.data.DateTest > testBuilder STARTED

org.apache.kafka.connect.data.DateTest > testBuilder PASSED

org.apache.kafka.connect.data.DateTest > testToLogicalInvalidSchema STARTED

org.apache.kafka.connect.data.DateTest > testToLogicalInvalidSchema PASSED

org.apache.kafka.connect.util.ConnectorUtilsTest > testGroupPartitions STARTED

org.apache.kafka.connect.util.ConnectorUtilsTest > testGroupPartitions PASSED

org.apache.kafka.connect.util.ConnectorUtilsTest > testGroupPartitionsInvalidCount STARTED

org.apache.kafka.connect.util.ConnectorUtilsTest > testGroupPartitionsInvalidCount PASSED

org.apache.kafka.connect.header.ConnectHeaderTest > shouldGetSchemaFromStruct STARTED

org.apache.kafka.connect.header.ConnectHeaderTest > shouldGetSchemaFromStruct PASSED

org.apache.kafka.connect.header.ConnectHeaderTest > shouldAllowNonNullValue STARTED

org.apache.kafka.connect.header.ConnectHeaderTest > shouldAllowNonNullValue PASSED

org.apache.kafka.connect.header.ConnectHeaderTest > shouldSatisfyEquals STARTED

org.apache.kafka.connect.header.ConnectHeaderTest > shouldSatisfyEquals PASSED

org.apache.kafka.connect.header.ConnectHeaderTest > shouldAllowNullSchema STARTED

org.apache.kafka.connect.header.ConnectHeaderTest > shouldAllowNullSchema PASSED

org.apache.kafka.connect.header.ConnectHeaderTest > shouldAllowNullValues STARTED

org.apache.kafka.connect.header.ConnectHeaderTest > shouldAllowNullValues PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldNotAllowNullKey STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldNotAllowNullKey PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldValidateLogicalTypes STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldValidateLogicalTypes PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldHaveToString STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldHaveToString PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldRemoveAllHeadersWithSameKeyWhenEmpty STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldRemoveAllHeadersWithSameKeyWhenEmpty PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldTransformHeadersWithKey STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldTransformHeadersWithKey PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddDate STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddDate PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddTime STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddTime PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldNotAddHeadersWithObjectValuesAndMismatchedSchema STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldNotAddHeadersWithObjectValuesAndMismatchedSchema PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldNotValidateMismatchedValuesWithBuiltInTypes STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldNotValidateMismatchedValuesWithBuiltInTypes PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldRemoveAllHeadersWithSameKey STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldRemoveAllHeadersWithSameKey PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldTransformAndRemoveHeaders STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldTransformAndRemoveHeaders PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldBeEquals STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldBeEquals PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldValidateBuildInTypes STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldValidateBuildInTypes PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldRemoveAllHeaders STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldRemoveAllHeaders PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldTransformHeadersWhenEmpty STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldTransformHeadersWhenEmpty PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldNotValidateNullValuesWithBuiltInTypes STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldNotValidateNullValuesWithBuiltInTypes PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldTransformHeaders STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldTransformHeaders PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddMultipleHeadersWithSameKeyAndRetainLatest STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddMultipleHeadersWithSameKeyAndRetainLatest PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldRetainLatestWhenEmpty STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldRetainLatestWhenEmpty PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddHeadersWithPrimitiveValues STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddHeadersWithPrimitiveValues PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldNotAddHeadersWithNullObjectValuesWithNonOptionalSchema STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldNotAddHeadersWithNullObjectValuesWithNonOptionalSchema PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldDuplicateAndAlwaysReturnEquivalentButDifferentObject STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldDuplicateAndAlwaysReturnEquivalentButDifferentObject PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddTimestamp STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddTimestamp PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddDecimal STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddDecimal PASSED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddHeadersWithNullObjectValuesWithOptionalSchema STARTED

org.apache.kafka.connect.header.ConnectHeadersTest > shouldAddHeadersWithNullObjectValuesWithOptionalSchema PASSED

org.apache.kafka.connect.connector.ConnectorReconfigurationTest > testReconfigureStopException STARTED

org.apache.kafka.connect.connector.ConnectorReconfigurationTest > testReconfigureStopException PASSED

org.apache.kafka.connect.connector.ConnectorReconfigurationTest > testDefaultReconfigure STARTED

org.apache.kafka.connect.connector.ConnectorReconfigurationTest > testDefaultReconfigure PASSED

org.apache.kafka.connect.source.SourceRecordTest > shouldDuplicateRecordAndCloneHeaders STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldDuplicateRecordAndCloneHeaders PASSED

org.apache.kafka.connect.source.SourceRecordTest > shouldDuplicateRecordUsingNewHeaders STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldDuplicateRecordUsingNewHeaders PASSED

org.apache.kafka.connect.source.SourceRecordTest > shouldModifyRecordHeader STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldModifyRecordHeader PASSED

org.apache.kafka.connect.source.SourceRecordTest > shouldCreateSinkRecordWithHeaders STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldCreateSinkRecordWithHeaders PASSED

org.apache.kafka.connect.source.SourceRecordTest > shouldCreateSinkRecordWithEmtpyHeaders STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldCreateSinkRecordWithEmtpyHeaders PASSED

org.apache.kafka.connect.sink.SinkRecordTest > shouldDuplicateRecordAndCloneHeaders STARTED

org.apache.kafka.connect.sink.SinkRecordTest > shouldDuplicateRecordAndCloneHeaders PASSED

org.apache.kafka.connect.sink.SinkRecordTest > shouldCreateSinkRecordWithEmptyHeaders STARTED

org.apache.kafka.connect.sink.SinkRecordTest > shouldCreateSinkRecordWithEmptyHeaders PASSED

org.apache.kafka.connect.sink.SinkRecordTest > shouldDuplicateRecordUsingNewHeaders STARTED

org.apache.kafka.connect.sink.SinkRecordTest > shouldDuplicateRecordUsingNewHeaders PASSED

org.apache.kafka.connect.sink.SinkRecordTest > shouldModifyRecordHeader STARTED

org.apache.kafka.connect.sink.SinkRecordTest > shouldModifyRecordHeader PASSED

org.apache.kafka.connect.sink.SinkRecordTest > shouldCreateSinkRecordWithHeaders STARTED

org.apache.kafka.connect.sink.SinkRecordTest > shouldCreateSinkRecordWithHeaders PASSED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':connect:runtime:test'.
> Process 'Gradle Test Executor 20' finished with non-zero exit value 1
  This problem might be caused by incorrect test process configuration.
  Please refer to the test execution section in the User Manual at https://docs.gradle.org/5.4.1/userguide/java_testing.html#sec:test_execution

* 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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 42m 2s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #560

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

Changes:

[manikumar] MINOR: Use `jps` cmd to find out the pid of TransactionalMessageCopier

------------------------------------------
[...truncated 2.48 MB...]
org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testBlankTopic PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testSourceTasks STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testSourceTasks PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testMissingTopic STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testMissingTopic PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testSourceTasksStdin STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testSourceTasksStdin PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testTaskClass STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testTaskClass PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testInvalidBatchSize STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testInvalidBatchSize PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testConnectorConfigValidation STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testConnectorConfigValidation PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testMultipleSourcesInvalid STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testMultipleSourcesInvalid PASSED

> Task :streams:streams-scala:test

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaJoin STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaJoin PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaSimple STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaSimple PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaAggregate STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaAggregate PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaProperties STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaProperties PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaTransform STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaTransform PASSED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsMaterialized STARTED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsMaterialized PASSED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsJava STARTED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsJava PASSED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWords STARTED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWords PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > filter a KStream should filter records satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > filter a KStream should filter records satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > filterNot a KStream should filter records not satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > filterNot a KStream should filter records not satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > foreach a KStream should run foreach actions on records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > foreach a KStream should run foreach actions on records PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > peek a KStream should run peek actions on records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > peek a KStream should run peek actions on records PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > selectKey a KStream should select a new key STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > selectKey a KStream should select a new key PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > join 2 KStreams should join correctly records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > join 2 KStreams should join correctly records PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialized should create a Materialized with Serdes STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialized should create a Materialized with Serdes PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a store name should create a Materialized with Serdes and a store name STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a store name should create a Materialized with Serdes and a store name PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a window store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a window store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a key value store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a key value store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a session store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a session store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.GroupedTest > Create a Grouped should create a Grouped with Serdes STARTED

org.apache.kafka.streams.scala.kstream.GroupedTest > Create a Grouped should create a Grouped with Serdes PASSED

org.apache.kafka.streams.scala.kstream.GroupedTest > Create a Grouped with repartition topic name should create a Grouped with Serdes, and repartition topic name STARTED

org.apache.kafka.streams.scala.kstream.GroupedTest > Create a Grouped with repartition topic name should create a Grouped with Serdes, and repartition topic name PASSED

org.apache.kafka.streams.scala.kstream.JoinedTest > Create a Joined should create a Joined with Serdes STARTED

org.apache.kafka.streams.scala.kstream.JoinedTest > Create a Joined should create a Joined with Serdes PASSED

org.apache.kafka.streams.scala.kstream.JoinedTest > Create a Joined should create a Joined with Serdes and repartition topic name STARTED

org.apache.kafka.streams.scala.kstream.JoinedTest > Create a Joined should create a Joined with Serdes and repartition topic name PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed should create a Consumed with Serdes STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed should create a Consumed with Serdes PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor should create a Consumed with Serdes and timestampExtractor STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor should create a Consumed with Serdes and timestampExtractor PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with resetPolicy should create a Consumed with Serdes and resetPolicy STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with resetPolicy should create a Consumed with Serdes and resetPolicy PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > filter a KTable should filter records satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > filter a KTable should filter records satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > filterNot a KTable should filter records not satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > filterNot a KTable should filter records not satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables should join correctly records STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables should join correctly records PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables with a Materialized should join correctly records and state store STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables with a Materialized should join correctly records and state store PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > windowed KTable#suppress should correctly suppress results using Suppressed.untilTimeLimit STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > windowed KTable#suppress should correctly suppress results using Suppressed.untilTimeLimit PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > windowed KTable#suppress should correctly suppress results using Suppressed.untilWindowCloses STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > windowed KTable#suppress should correctly suppress results using Suppressed.untilWindowCloses PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > session windowed KTable#suppress should correctly suppress results using Suppressed.untilWindowCloses STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > session windowed KTable#suppress should correctly suppress results using Suppressed.untilWindowCloses PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > non-windowed KTable#suppress should correctly suppress results using Suppressed.untilTimeLimit STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > non-windowed KTable#suppress should correctly suppress results using Suppressed.untilTimeLimit PASSED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced should create a Produced with Serdes STARTED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced should create a Produced with Serdes PASSED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy STARTED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy PASSED

org.apache.kafka.streams.scala.kstream.SuppressedTest > Suppressed.untilWindowCloses should produce the correct suppression STARTED

org.apache.kafka.streams.scala.kstream.SuppressedTest > Suppressed.untilWindowCloses should produce the correct suppression PASSED

org.apache.kafka.streams.scala.kstream.SuppressedTest > Suppressed.untilTimeLimit should produce the correct suppression STARTED

org.apache.kafka.streams.scala.kstream.SuppressedTest > Suppressed.untilTimeLimit should produce the correct suppression PASSED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig.maxRecords should produce the correct buffer config STARTED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig.maxRecords should produce the correct buffer config PASSED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig.maxBytes should produce the correct buffer config STARTED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig.maxBytes should produce the correct buffer config PASSED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig.unbounded should produce the correct buffer config STARTED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig.unbounded should produce the correct buffer config PASSED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig should support very long chains of factory methods STARTED

org.apache.kafka.streams.scala.kstream.SuppressedTest > BufferConfig should support very long chains of factory methods PASSED

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegionWithNamedRepartitionTopic STARTED

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegionWithNamedRepartitionTopic PASSED

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegionJava STARTED

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegionJava PASSED

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegion STARTED

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegion PASSED

> Task :streams:examples:test

org.apache.kafka.streams.examples.wordcount.WordCountProcessorTest > test STARTED

org.apache.kafka.streams.examples.wordcount.WordCountProcessorTest > test PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 47m 23s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #559

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

Changes:

[github] HOTFIX: Fix recent protocol breakage from KIP-345 and KIP-392 (#6780)

------------------------------------------
[...truncated 2.50 MB...]
org.apache.kafka.connect.json.JsonConverterTest > timestampToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullValueToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullValueToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > stringHeaderToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > stringHeaderToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonNonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonNonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > longToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > longToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > mismatchSchemaJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > mismatchSchemaJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectNonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectNonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > testJsonSchemaMetadataTranslation STARTED

org.apache.kafka.connect.json.JsonConverterTest > testJsonSchemaMetadataTranslation PASSED

org.apache.kafka.connect.json.JsonConverterTest > bytesToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > bytesToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > shortToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > shortToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > intToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > intToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndNullValueToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndNullValueToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > structToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > structToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > stringToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > stringToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndArrayToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndArrayToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > byteToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > byteToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaPrimitiveToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaPrimitiveToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > byteToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > byteToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > intToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > intToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > noSchemaToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndPrimitiveToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullSchemaAndPrimitiveToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToJsonStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > arrayToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > arrayToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > nullToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > nullToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > structToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > structToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > testConnectSchemaMetadataTranslation STARTED

org.apache.kafka.connect.json.JsonConverterTest > testConnectSchemaMetadataTranslation PASSED

org.apache.kafka.connect.json.JsonConverterTest > shortToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > shortToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > doubleToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > doubleToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > testStringHeaderToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > testStringHeaderToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > structSchemaIdentical STARTED

org.apache.kafka.connect.json.JsonConverterTest > structSchemaIdentical PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectStringKeys STARTED

org.apache.kafka.connect.json.JsonConverterTest > mapToConnectStringKeys PASSED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptional STARTED

org.apache.kafka.connect.json.JsonConverterTest > dateToConnectOptional PASSED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timeToConnectOptionalWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > floatToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > floatToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToConnectWithDefaultValue PASSED

org.apache.kafka.connect.json.JsonConverterTest > decimalToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > decimalToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > arrayToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > arrayToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > testCacheSchemaToConnectConversion STARTED

org.apache.kafka.connect.json.JsonConverterTest > testCacheSchemaToConnectConversion PASSED

org.apache.kafka.connect.json.JsonConverterTest > booleanToJson STARTED

org.apache.kafka.connect.json.JsonConverterTest > booleanToJson PASSED

org.apache.kafka.connect.json.JsonConverterTest > bytesToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > bytesToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > doubleToConnect STARTED

org.apache.kafka.connect.json.JsonConverterTest > doubleToConnect PASSED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptionalWithDefaultValue STARTED

org.apache.kafka.connect.json.JsonConverterTest > timestampToConnectOptionalWithDefaultValue PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 30m 21s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #558

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

Changes:

[github] MINOR: A few logging improvements in the broker (#6773)

[jason] MINOR: Set `replicaId` for OffsetsForLeaderEpoch from followers (#6775)

------------------------------------------
[...truncated 2.47 MB...]
org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessDateToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimeToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimeToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaUnixToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaUnixToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessIdentity STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessIdentity PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaFieldConversion STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaFieldConversion PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaDateToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaDateToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaIdentity STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaIdentity PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigMissingFormat STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigMissingFormat PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigNoTargetType STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigNoTargetType PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaStringToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaStringToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimeToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimeToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessUnixToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessUnixToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidFormat STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidFormat PASSED

org.apache.kafka.connect.transforms.TimestampRouterTest > defaultConfiguration STARTED

org.apache.kafka.connect.transforms.TimestampRouterTest > defaultConfiguration PASSED

org.apache.kafka.connect.transforms.RegexRouterTest > doesntMatch STARTED

org.apache.kafka.connect.transforms.RegexRouterTest > doesntMatch PASSED

org.apache.kafka.connect.transforms.RegexRouterTest > identity STARTED

org.apache.kafka.connect.transforms.RegexRouterTest > identity PASSED

org.apache.kafka.connect.transforms.RegexRouterTest > addPrefix STARTED

org.apache.kafka.connect.transforms.RegexRouterTest > addPrefix PASSED

org.apache.kafka.connect.transforms.RegexRouterTest > addSuffix STARTED

org.apache.kafka.connect.transforms.RegexRouterTest > addSuffix PASSED

org.apache.kafka.connect.transforms.RegexRouterTest > slice STARTED

org.apache.kafka.connect.transforms.RegexRouterTest > slice PASSED

org.apache.kafka.connect.transforms.RegexRouterTest > staticReplacement STARTED

org.apache.kafka.connect.transforms.RegexRouterTest > staticReplacement PASSED

org.apache.kafka.connect.transforms.ValueToKeyTest > withSchema STARTED

org.apache.kafka.connect.transforms.ValueToKeyTest > withSchema PASSED

org.apache.kafka.connect.transforms.ValueToKeyTest > schemaless STARTED

org.apache.kafka.connect.transforms.ValueToKeyTest > schemaless PASSED

org.apache.kafka.connect.transforms.InsertFieldTest > schemalessInsertConfiguredFields STARTED

org.apache.kafka.connect.transforms.InsertFieldTest > schemalessInsertConfiguredFields PASSED

org.apache.kafka.connect.transforms.InsertFieldTest > topLevelStructRequired STARTED

org.apache.kafka.connect.transforms.InsertFieldTest > topLevelStructRequired PASSED

org.apache.kafka.connect.transforms.InsertFieldTest > copySchemaAndInsertConfiguredFields STARTED

org.apache.kafka.connect.transforms.InsertFieldTest > copySchemaAndInsertConfiguredFields PASSED

org.apache.kafka.connect.transforms.ReplaceFieldTest > withSchema STARTED

org.apache.kafka.connect.transforms.ReplaceFieldTest > withSchema PASSED

org.apache.kafka.connect.transforms.ReplaceFieldTest > schemaless STARTED

org.apache.kafka.connect.transforms.ReplaceFieldTest > schemaless PASSED

org.apache.kafka.connect.transforms.MaskFieldTest > withSchema STARTED

org.apache.kafka.connect.transforms.MaskFieldTest > withSchema PASSED

org.apache.kafka.connect.transforms.MaskFieldTest > schemaless STARTED

org.apache.kafka.connect.transforms.MaskFieldTest > schemaless PASSED

org.apache.kafka.connect.transforms.util.NonEmptyListValidatorTest > testNullList STARTED

org.apache.kafka.connect.transforms.util.NonEmptyListValidatorTest > testNullList PASSED

org.apache.kafka.connect.transforms.util.NonEmptyListValidatorTest > testEmptyList STARTED

org.apache.kafka.connect.transforms.util.NonEmptyListValidatorTest > testEmptyList PASSED

org.apache.kafka.connect.transforms.util.NonEmptyListValidatorTest > testValidList STARTED

org.apache.kafka.connect.transforms.util.NonEmptyListValidatorTest > testValidList PASSED

org.apache.kafka.connect.transforms.FlattenTest > testKey STARTED

org.apache.kafka.connect.transforms.FlattenTest > testKey PASSED

org.apache.kafka.connect.transforms.FlattenTest > testOptionalAndDefaultValuesNested STARTED

org.apache.kafka.connect.transforms.FlattenTest > testOptionalAndDefaultValuesNested PASSED

org.apache.kafka.connect.transforms.FlattenTest > topLevelMapRequired STARTED

org.apache.kafka.connect.transforms.FlattenTest > topLevelMapRequired PASSED

org.apache.kafka.connect.transforms.FlattenTest > topLevelStructRequired STARTED

org.apache.kafka.connect.transforms.FlattenTest > topLevelStructRequired PASSED

org.apache.kafka.connect.transforms.FlattenTest > testOptionalFieldStruct STARTED

org.apache.kafka.connect.transforms.FlattenTest > testOptionalFieldStruct PASSED

org.apache.kafka.connect.transforms.FlattenTest > testNestedMapWithDelimiter STARTED

org.apache.kafka.connect.transforms.FlattenTest > testNestedMapWithDelimiter PASSED

org.apache.kafka.connect.transforms.FlattenTest > testOptionalFieldMap STARTED

org.apache.kafka.connect.transforms.FlattenTest > testOptionalFieldMap PASSED

org.apache.kafka.connect.transforms.FlattenTest > testUnsupportedTypeInMap STARTED

org.apache.kafka.connect.transforms.FlattenTest > testUnsupportedTypeInMap PASSED

org.apache.kafka.connect.transforms.FlattenTest > testNestedStruct STARTED

org.apache.kafka.connect.transforms.FlattenTest > testNestedStruct PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameUpdate STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameUpdate PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameAndVersionUpdateWithStruct STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameAndVersionUpdateWithStruct PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfStruct STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfStruct PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameAndVersionUpdate STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameAndVersionUpdate PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfNull STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfNull PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaVersionUpdate STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaVersionUpdate PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfNonStruct STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfNonStruct PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 37m 47s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #557

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

Changes:

[wangguoz] KAFKA-8315: fix the JoinWindows retention deprecation doc (#6664)

[github] KAFKA-8052; Ensure fetch session epoch is updated before new request

------------------------------------------
[...truncated 2.38 MB...]
        at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.start(EmbeddedConnectCluster.java:132)
        at org.apache.kafka.connect.integration.RebalanceSourceConnectorsIntegrationTest.setup(RebalanceSourceConnectorsIntegrationTest.java:92)

    java.lang.RuntimeException: Could not stop brokers
        at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.stop(EmbeddedConnectCluster.java:148)
        at org.apache.kafka.connect.integration.RebalanceSourceConnectorsIntegrationTest.close(RebalanceSourceConnectorsIntegrationTest.java:98)

        Caused by:
        java.lang.RuntimeException: Could not shutdown producer
            at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.stop(EmbeddedKafkaCluster.java:141)
            at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.after(EmbeddedKafkaCluster.java:102)
            at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.stop(EmbeddedConnectCluster.java:143)
            ... 1 more

            Caused by:
            java.lang.NullPointerException
                at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.stop(EmbeddedKafkaCluster.java:138)
                ... 3 more

org.apache.kafka.connect.integration.ErrorHandlingIntegrationTest > testSkipRetryAndDLQWithHeaders STARTED
org.apache.kafka.connect.integration.ErrorHandlingIntegrationTest.testSkipRetryAndDLQWithHeaders failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/connect/runtime/build/reports/testOutput/org.apache.kafka.connect.integration.ErrorHandlingIntegrationTest.testSkipRetryAndDLQWithHeaders.test.stdout>

org.apache.kafka.connect.integration.ErrorHandlingIntegrationTest > testSkipRetryAndDLQWithHeaders FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.base/java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.base/java.lang.Runtime.addShutdownHook(Runtime.java:215)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:261)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:231)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:241)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:95)
        at kafka.zk.EmbeddedZookeeper.<init>(EmbeddedZookeeper.scala:39)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.start(EmbeddedKafkaCluster.java:106)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.before(EmbeddedKafkaCluster.java:97)
        at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.start(EmbeddedConnectCluster.java:132)
        at org.apache.kafka.connect.integration.ErrorHandlingIntegrationTest.setup(ErrorHandlingIntegrationTest.java:90)

    java.lang.RuntimeException: Could not stop brokers
        at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.stop(EmbeddedConnectCluster.java:148)
        at org.apache.kafka.connect.integration.ErrorHandlingIntegrationTest.close(ErrorHandlingIntegrationTest.java:99)

        Caused by:
        java.lang.RuntimeException: Could not shutdown producer
            at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.stop(EmbeddedKafkaCluster.java:141)
            at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.after(EmbeddedKafkaCluster.java:102)
            at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.stop(EmbeddedConnectCluster.java:143)
            ... 1 more

            Caused by:
            java.lang.NullPointerException
                at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.stop(EmbeddedKafkaCluster.java:138)
                ... 3 more

org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest > testCreateWithNotAllowedOverridesForPrincipalPolicy STARTED
org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.testCreateWithNotAllowedOverridesForPrincipalPolicy failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/connect/runtime/build/reports/testOutput/org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.testCreateWithNotAllowedOverridesForPrincipalPolicy.test.stdout>

org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest > testCreateWithNotAllowedOverridesForPrincipalPolicy FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.base/java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.base/java.lang.Runtime.addShutdownHook(Runtime.java:215)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:261)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:231)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:241)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:95)
        at kafka.zk.EmbeddedZookeeper.<init>(EmbeddedZookeeper.scala:39)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.start(EmbeddedKafkaCluster.java:106)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.before(EmbeddedKafkaCluster.java:97)
        at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.start(EmbeddedConnectCluster.java:132)
        at org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.connectClusterWithPolicy(ConnectorCientPolicyIntegrationTest.java:108)
        at org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.assertFailCreateConnector(ConnectorCientPolicyIntegrationTest.java:113)
        at org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.testCreateWithNotAllowedOverridesForPrincipalPolicy(ConnectorCientPolicyIntegrationTest.java:70)

org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest > testCreateWithAllowedOverridesForAllPolicy STARTED
org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.testCreateWithAllowedOverridesForAllPolicy failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/connect/runtime/build/reports/testOutput/org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.testCreateWithAllowedOverridesForAllPolicy.test.stdout>

org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest > testCreateWithAllowedOverridesForAllPolicy FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.base/java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.base/java.lang.Runtime.addShutdownHook(Runtime.java:215)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:261)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:231)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:241)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:95)
        at kafka.zk.EmbeddedZookeeper.<init>(EmbeddedZookeeper.scala:39)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.start(EmbeddedKafkaCluster.java:106)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.before(EmbeddedKafkaCluster.java:97)
        at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.start(EmbeddedConnectCluster.java:132)
        at org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.connectClusterWithPolicy(ConnectorCientPolicyIntegrationTest.java:108)
        at org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.assertPassCreateConnector(ConnectorCientPolicyIntegrationTest.java:125)
        at org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.testCreateWithAllowedOverridesForAllPolicy(ConnectorCientPolicyIntegrationTest.java:85)

org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest > testCreateWithAllowedOverridesForPrincipalPolicy STARTED
org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.testCreateWithAllowedOverridesForPrincipalPolicy failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/connect/runtime/build/reports/testOutput/org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.testCreateWithAllowedOverridesForPrincipalPolicy.test.stdout>

org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest > testCreateWithAllowedOverridesForPrincipalPolicy FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.base/java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.base/java.lang.Runtime.addShutdownHook(Runtime.java:215)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:261)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:231)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:241)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:95)
        at kafka.zk.EmbeddedZookeeper.<init>(EmbeddedZookeeper.scala:39)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.start(EmbeddedKafkaCluster.java:106)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.before(EmbeddedKafkaCluster.java:97)
        at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.start(EmbeddedConnectCluster.java:132)
        at org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.connectClusterWithPolicy(ConnectorCientPolicyIntegrationTest.java:108)
        at org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.assertPassCreateConnector(ConnectorCientPolicyIntegrationTest.java:125)
        at org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.testCreateWithAllowedOverridesForPrincipalPolicy(ConnectorCientPolicyIntegrationTest.java:77)

org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest > testCreateWithOverridesForNonePolicy STARTED
org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.testCreateWithOverridesForNonePolicy failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/connect/runtime/build/reports/testOutput/org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.testCreateWithOverridesForNonePolicy.test.stdout>

org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest > testCreateWithOverridesForNonePolicy FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.base/java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.base/java.lang.Runtime.addShutdownHook(Runtime.java:215)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:261)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:231)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:241)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:95)
        at kafka.zk.EmbeddedZookeeper.<init>(EmbeddedZookeeper.scala:39)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.start(EmbeddedKafkaCluster.java:106)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.before(EmbeddedKafkaCluster.java:97)
        at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.start(EmbeddedConnectCluster.java:132)
        at org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.connectClusterWithPolicy(ConnectorCientPolicyIntegrationTest.java:108)
        at org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.assertFailCreateConnector(ConnectorCientPolicyIntegrationTest.java:113)
        at org.apache.kafka.connect.integration.ConnectorCientPolicyIntegrationTest.testCreateWithOverridesForNonePolicy(ConnectorCientPolicyIntegrationTest.java:62)

org.apache.kafka.connect.integration.ConnectWorkerIntegrationTest > testAddAndRemoveWorker STARTED
org.apache.kafka.connect.integration.ConnectWorkerIntegrationTest.testAddAndRemoveWorker failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/connect/runtime/build/reports/testOutput/org.apache.kafka.connect.integration.ConnectWorkerIntegrationTest.testAddAndRemoveWorker.test.stdout>

org.apache.kafka.connect.integration.ConnectWorkerIntegrationTest > testAddAndRemoveWorker FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.base/java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.base/java.lang.Runtime.addShutdownHook(Runtime.java:215)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:261)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:231)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:241)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:95)
        at kafka.zk.EmbeddedZookeeper.<init>(EmbeddedZookeeper.scala:39)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.start(EmbeddedKafkaCluster.java:106)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.before(EmbeddedKafkaCluster.java:97)
        at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.start(EmbeddedConnectCluster.java:132)
        at org.apache.kafka.connect.integration.ConnectWorkerIntegrationTest.setup(ConnectWorkerIntegrationTest.java:84)

    java.lang.RuntimeException: Could not stop brokers
        at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.stop(EmbeddedConnectCluster.java:148)
        at org.apache.kafka.connect.integration.ConnectWorkerIntegrationTest.close(ConnectWorkerIntegrationTest.java:90)

        Caused by:
        java.lang.RuntimeException: Could not shutdown producer
            at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.stop(EmbeddedKafkaCluster.java:141)
            at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.after(EmbeddedKafkaCluster.java:102)
            at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.stop(EmbeddedConnectCluster.java:143)
            ... 1 more

            Caused by:
            java.lang.NullPointerException
                at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.stop(EmbeddedKafkaCluster.java:138)
                ... 3 more

org.apache.kafka.connect.integration.RestExtensionIntegrationTest > testImmediateRequestForListOfConnectors STARTED
org.apache.kafka.connect.integration.RestExtensionIntegrationTest.testImmediateRequestForListOfConnectors failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/connect/runtime/build/reports/testOutput/org.apache.kafka.connect.integration.RestExtensionIntegrationTest.testImmediateRequestForListOfConnectors.test.stdout>

org.apache.kafka.connect.integration.RestExtensionIntegrationTest > testImmediateRequestForListOfConnectors FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.base/java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.base/java.lang.Runtime.addShutdownHook(Runtime.java:215)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:261)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:231)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:241)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:95)
        at kafka.zk.EmbeddedZookeeper.<init>(EmbeddedZookeeper.scala:39)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.start(EmbeddedKafkaCluster.java:106)
        at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.before(EmbeddedKafkaCluster.java:97)
        at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.start(EmbeddedConnectCluster.java:132)
        at org.apache.kafka.connect.integration.RestExtensionIntegrationTest.testImmediateRequestForListOfConnectors(RestExtensionIntegrationTest.java:64)

    java.lang.RuntimeException: Could not stop brokers
        at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.stop(EmbeddedConnectCluster.java:148)
        at org.apache.kafka.connect.integration.RestExtensionIntegrationTest.close(RestExtensionIntegrationTest.java:76)

        Caused by:
        java.lang.RuntimeException: Could not shutdown producer
            at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.stop(EmbeddedKafkaCluster.java:141)
            at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.after(EmbeddedKafkaCluster.java:102)
            at org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.stop(EmbeddedConnectCluster.java:143)
            ... 1 more

            Caused by:
            java.lang.NullPointerException
                at org.apache.kafka.connect.util.clusters.EmbeddedKafkaCluster.stop(EmbeddedKafkaCluster.java:138)
                ... 3 more

org.apache.kafka.connect.runtime.SourceTaskOffsetCommitterTest > testClose STARTED
WARNING: An illegal reflective access operation has occurred
WARNING: Illegal reflective access by org.powermock.reflect.internal.WhiteboxImpl (file:/home/jenkins/.gradle/caches/modules-2/files-2.1/org.powermock/powermock-reflect/2.0.2/79df0e5792fba38278b90f9e22617f5684313017/powermock-reflect-2.0.2.jar) to method java.lang.Object.clone()
WARNING: Please consider reporting this to the maintainers of org.powermock.reflect.internal.WhiteboxImpl
WARNING: Use --illegal-access=warn to enable warnings of further illegal reflective access operations
WARNING: All illegal access operations will be denied in a future release

org.apache.kafka.connect.runtime.SourceTaskOffsetCommitterTest > testClose SKIPPED

14 tests completed, 9 failed, 1 skipped

> Task :connect:runtime:test FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':connect:runtime:test'.
> Process 'Gradle Test Executor 20' finished with non-zero exit value 1
  This problem might be caused by incorrect test process configuration.
  Please refer to the test execution section in the User Manual at https://docs.gradle.org/5.4.1/userguide/java_testing.html#sec:test_execution

* 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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 20m 52s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #556

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

Changes:

[rhauch] KAFKA-8265: Fix override config name to match KIP-458. (#6776)

------------------------------------------
[...truncated 2.50 MB...]
org.apache.kafka.trogdor.workload.PayloadGeneratorTest > testNullPayloadGenerator STARTED

org.apache.kafka.trogdor.workload.PayloadGeneratorTest > testNullPayloadGenerator PASSED

org.apache.kafka.trogdor.workload.PayloadGeneratorTest > testUniformRandomPayloadGenerator STARTED

org.apache.kafka.trogdor.workload.PayloadGeneratorTest > testUniformRandomPayloadGenerator PASSED

org.apache.kafka.trogdor.workload.PayloadGeneratorTest > testPayloadIterator STARTED

org.apache.kafka.trogdor.workload.PayloadGeneratorTest > testPayloadIterator PASSED

org.apache.kafka.trogdor.workload.PayloadGeneratorTest > testUniformRandomPayloadGeneratorPaddingBytes STARTED

org.apache.kafka.trogdor.workload.PayloadGeneratorTest > testUniformRandomPayloadGeneratorPaddingBytes PASSED

org.apache.kafka.trogdor.workload.ThrottleTest > testThrottle STARTED

org.apache.kafka.trogdor.workload.ThrottleTest > testThrottle PASSED

org.apache.kafka.trogdor.workload.TimeIntervalTransactionsGeneratorTest > testCommitsTransactionAfterIntervalPasses STARTED

org.apache.kafka.trogdor.workload.TimeIntervalTransactionsGeneratorTest > testCommitsTransactionAfterIntervalPasses PASSED

org.apache.kafka.trogdor.workload.ExternalCommandWorkerTest > testProcessWithFailedExit STARTED

org.apache.kafka.trogdor.workload.ExternalCommandWorkerTest > testProcessWithFailedExit PASSED

org.apache.kafka.trogdor.workload.ExternalCommandWorkerTest > testProcessNotFound STARTED

org.apache.kafka.trogdor.workload.ExternalCommandWorkerTest > testProcessNotFound PASSED

org.apache.kafka.trogdor.workload.ExternalCommandWorkerTest > testProcessForceKillTimeout STARTED

org.apache.kafka.trogdor.workload.ExternalCommandWorkerTest > testProcessForceKillTimeout PASSED

org.apache.kafka.trogdor.workload.ExternalCommandWorkerTest > testProcessStop STARTED

org.apache.kafka.trogdor.workload.ExternalCommandWorkerTest > testProcessStop PASSED

org.apache.kafka.trogdor.workload.ExternalCommandWorkerTest > testProcessWithNormalExit STARTED

org.apache.kafka.trogdor.workload.ExternalCommandWorkerTest > testProcessWithNormalExit PASSED

org.apache.kafka.trogdor.workload.TopicsSpecTest > testPartitionNumbers STARTED

org.apache.kafka.trogdor.workload.TopicsSpecTest > testPartitionNumbers PASSED

org.apache.kafka.trogdor.workload.TopicsSpecTest > testMaterialize STARTED

org.apache.kafka.trogdor.workload.TopicsSpecTest > testMaterialize PASSED

org.apache.kafka.trogdor.workload.TopicsSpecTest > testPartitionsSpec STARTED

org.apache.kafka.trogdor.workload.TopicsSpecTest > testPartitionsSpec PASSED

org.apache.kafka.trogdor.workload.HistogramTest > testHistogramPercentiles STARTED

org.apache.kafka.trogdor.workload.HistogramTest > testHistogramPercentiles PASSED

org.apache.kafka.trogdor.workload.HistogramTest > testHistogramSamples STARTED

org.apache.kafka.trogdor.workload.HistogramTest > testHistogramSamples PASSED

org.apache.kafka.trogdor.workload.HistogramTest > testHistogramAverage STARTED

org.apache.kafka.trogdor.workload.HistogramTest > testHistogramAverage PASSED

org.apache.kafka.trogdor.basic.BasicPlatformTest > testCreateBasicPlatform STARTED

org.apache.kafka.trogdor.basic.BasicPlatformTest > testCreateBasicPlatform PASSED

org.apache.kafka.trogdor.agent.AgentTest > testAgentCreateWorkers STARTED

org.apache.kafka.trogdor.agent.AgentTest > testAgentCreateWorkers PASSED

org.apache.kafka.trogdor.agent.AgentTest > testAgentGetStatus STARTED

org.apache.kafka.trogdor.agent.AgentTest > testAgentGetStatus PASSED

org.apache.kafka.trogdor.agent.AgentTest > testAgentGetUptime STARTED

org.apache.kafka.trogdor.agent.AgentTest > testAgentGetUptime PASSED

org.apache.kafka.trogdor.agent.AgentTest > testAgentStartShutdown STARTED

org.apache.kafka.trogdor.agent.AgentTest > testAgentStartShutdown PASSED

org.apache.kafka.trogdor.agent.AgentTest > testCreateExpiredWorkerIsNotScheduled STARTED

org.apache.kafka.trogdor.agent.AgentTest > testCreateExpiredWorkerIsNotScheduled PASSED

org.apache.kafka.trogdor.agent.AgentTest > testAgentProgrammaticShutdown STARTED

org.apache.kafka.trogdor.agent.AgentTest > testAgentProgrammaticShutdown PASSED

org.apache.kafka.trogdor.agent.AgentTest > testDestroyWorkers STARTED

org.apache.kafka.trogdor.agent.AgentTest > testDestroyWorkers PASSED

org.apache.kafka.trogdor.agent.AgentTest > testKiboshFaults STARTED

org.apache.kafka.trogdor.agent.AgentTest > testKiboshFaults PASSED

org.apache.kafka.trogdor.agent.AgentTest > testAgentExecWithTimeout STARTED

org.apache.kafka.trogdor.agent.AgentTest > testAgentExecWithTimeout PASSED

org.apache.kafka.trogdor.agent.AgentTest > testAgentExecWithNormalExit STARTED

org.apache.kafka.trogdor.agent.AgentTest > testAgentExecWithNormalExit PASSED

org.apache.kafka.trogdor.agent.AgentTest > testWorkerCompletions STARTED

org.apache.kafka.trogdor.agent.AgentTest > testWorkerCompletions PASSED

org.apache.kafka.trogdor.agent.AgentTest > testAgentFinishesTasks STARTED

org.apache.kafka.trogdor.agent.AgentTest > testAgentFinishesTasks PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTaskRequest STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTaskRequest PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTaskDestruction STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTaskDestruction PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTasksRequestMatches STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTasksRequestMatches PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testWorkersExitingAtDifferentTimes STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testWorkersExitingAtDifferentTimes PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testAgentFailureAndTaskExpiry STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testAgentFailureAndTaskExpiry PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTaskDistribution STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTaskDistribution PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTaskRequestWithOldStartMsGetsUpdated STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTaskRequestWithOldStartMsGetsUpdated PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testNetworkPartitionFault STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testNetworkPartitionFault PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTaskRequestWithFutureStartMsDoesNotGetRun STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTaskRequestWithFutureStartMsDoesNotGetRun PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTaskCancellation STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTaskCancellation PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testCreateTask STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testCreateTask PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTasksRequest STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testTasksRequest PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testCoordinatorStatus STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testCoordinatorStatus PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testCoordinatorUptime STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testCoordinatorUptime PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorClientTest > testPrettyPrintTaskInfo STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorClientTest > testPrettyPrintTaskInfo PASSED

> Task :log4j-appender:test

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithSyncSendWithoutIgnoringExceptionsShouldNotThrowException STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithSyncSendWithoutIgnoringExceptionsShouldNotThrowException PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithRealProducerConfigWithSyncSendAndNotIgnoringExceptionsShouldThrowException STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithRealProducerConfigWithSyncSendAndNotIgnoringExceptionsShouldThrowException PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppends STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppends PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSetSaslMechanism STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSetSaslMechanism PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testJaasConfigNotSet STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testJaasConfigNotSet PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testKafkaLog4jConfigs STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testKafkaLog4jConfigs PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithSyncSendAndSimulateProducerFailShouldThrowException STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithSyncSendAndSimulateProducerFailShouldThrowException PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithRealProducerConfigWithSyncSendShouldNotThrowException STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithRealProducerConfigWithSyncSendShouldNotThrowException PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSaslMechanismNotSet STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSaslMechanismNotSet PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSetJaasConfig STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSetJaasConfig PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 41m 8s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #555

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

Changes:

[manikumar] KAFKA-3143: Controller should transition offline replicas on startup

------------------------------------------
[...truncated 2.46 MB...]
kafka.controller.ControllerEventManagerTest > testEventThatThrowsException PASSED

kafka.controller.ControllerEventManagerTest > testSuccessfulEvent STARTED

kafka.controller.ControllerEventManagerTest > testSuccessfulEvent PASSED

kafka.controller.TopicDeletionManagerTest > testBrokerFailureAfterDeletionStarted STARTED

kafka.controller.TopicDeletionManagerTest > testBrokerFailureAfterDeletionStarted PASSED

kafka.controller.TopicDeletionManagerTest > testInitialization STARTED

kafka.controller.TopicDeletionManagerTest > testInitialization PASSED

kafka.controller.TopicDeletionManagerTest > testBasicDeletion STARTED

kafka.controller.TopicDeletionManagerTest > testBasicDeletion PASSED

kafka.controller.TopicDeletionManagerTest > testDeletionWithBrokerOffline STARTED

kafka.controller.TopicDeletionManagerTest > testDeletionWithBrokerOffline PASSED

kafka.controller.ControllerFailoverTest > testHandleIllegalStateException STARTED

kafka.controller.ControllerFailoverTest > testHandleIllegalStateException PASSED

kafka.network.SocketServerTest > testGracefulClose STARTED

kafka.network.SocketServerTest > testGracefulClose PASSED

kafka.network.SocketServerTest > testSendActionResponseWithThrottledChannelWhereThrottlingAlreadyDone STARTED

kafka.network.SocketServerTest > testSendActionResponseWithThrottledChannelWhereThrottlingAlreadyDone PASSED

kafka.network.SocketServerTest > controlThrowable STARTED

kafka.network.SocketServerTest > controlThrowable PASSED

kafka.network.SocketServerTest > testRequestMetricsAfterStop STARTED

kafka.network.SocketServerTest > testRequestMetricsAfterStop PASSED

kafka.network.SocketServerTest > testConnectionIdReuse STARTED

kafka.network.SocketServerTest > testConnectionIdReuse PASSED

kafka.network.SocketServerTest > testClientDisconnectionUpdatesRequestMetrics STARTED

kafka.network.SocketServerTest > testClientDisconnectionUpdatesRequestMetrics PASSED

kafka.network.SocketServerTest > testProcessorMetricsTags STARTED

kafka.network.SocketServerTest > testProcessorMetricsTags PASSED

kafka.network.SocketServerTest > testMaxConnectionsPerIp STARTED

kafka.network.SocketServerTest > testMaxConnectionsPerIp PASSED

kafka.network.SocketServerTest > testConnectionId STARTED

kafka.network.SocketServerTest > testConnectionId PASSED

kafka.network.SocketServerTest > testBrokerSendAfterChannelClosedUpdatesRequestMetrics STARTED

kafka.network.SocketServerTest > testBrokerSendAfterChannelClosedUpdatesRequestMetrics PASSED

kafka.network.SocketServerTest > testNoOpAction STARTED

kafka.network.SocketServerTest > testNoOpAction PASSED

kafka.network.SocketServerTest > simpleRequest STARTED

kafka.network.SocketServerTest > simpleRequest PASSED

kafka.network.SocketServerTest > closingChannelException STARTED

kafka.network.SocketServerTest > closingChannelException PASSED

kafka.network.SocketServerTest > testSendActionResponseWithThrottledChannelWhereThrottlingInProgress STARTED

kafka.network.SocketServerTest > testSendActionResponseWithThrottledChannelWhereThrottlingInProgress PASSED

kafka.network.SocketServerTest > testIdleConnection STARTED

kafka.network.SocketServerTest > testIdleConnection PASSED

kafka.network.SocketServerTest > testClientDisconnectionWithStagedReceivesFullyProcessed STARTED

kafka.network.SocketServerTest > testClientDisconnectionWithStagedReceivesFullyProcessed PASSED

kafka.network.SocketServerTest > testZeroMaxConnectionsPerIp STARTED

kafka.network.SocketServerTest > testZeroMaxConnectionsPerIp PASSED

kafka.network.SocketServerTest > testMetricCollectionAfterShutdown STARTED

kafka.network.SocketServerTest > testMetricCollectionAfterShutdown PASSED

kafka.network.SocketServerTest > testSessionPrincipal STARTED

kafka.network.SocketServerTest > testSessionPrincipal PASSED

kafka.network.SocketServerTest > configureNewConnectionException STARTED

kafka.network.SocketServerTest > configureNewConnectionException PASSED

kafka.network.SocketServerTest > testMaxConnectionsPerIpOverrides STARTED

kafka.network.SocketServerTest > testMaxConnectionsPerIpOverrides PASSED

kafka.network.SocketServerTest > testControlPlaneRequest STARTED

kafka.network.SocketServerTest > testControlPlaneRequest PASSED

kafka.network.SocketServerTest > processNewResponseException STARTED

kafka.network.SocketServerTest > processNewResponseException PASSED

kafka.network.SocketServerTest > testConnectionRateLimit STARTED

kafka.network.SocketServerTest > testConnectionRateLimit PASSED

kafka.network.SocketServerTest > processCompletedSendException STARTED

kafka.network.SocketServerTest > processCompletedSendException PASSED

kafka.network.SocketServerTest > processDisconnectedException STARTED

kafka.network.SocketServerTest > processDisconnectedException PASSED

kafka.network.SocketServerTest > sendCancelledKeyException STARTED

kafka.network.SocketServerTest > sendCancelledKeyException PASSED

kafka.network.SocketServerTest > processCompletedReceiveException STARTED

kafka.network.SocketServerTest > processCompletedReceiveException PASSED

kafka.network.SocketServerTest > testSocketsCloseOnShutdown STARTED

kafka.network.SocketServerTest > testSocketsCloseOnShutdown PASSED

kafka.network.SocketServerTest > testNoOpActionResponseWithThrottledChannelWhereThrottlingAlreadyDone STARTED

kafka.network.SocketServerTest > testNoOpActionResponseWithThrottledChannelWhereThrottlingAlreadyDone PASSED

kafka.network.SocketServerTest > pollException STARTED

kafka.network.SocketServerTest > pollException PASSED

kafka.network.SocketServerTest > testSslSocketServer STARTED

kafka.network.SocketServerTest > testSslSocketServer PASSED

kafka.network.SocketServerTest > tooBigRequestIsRejected STARTED

kafka.network.SocketServerTest > tooBigRequestIsRejected PASSED

kafka.network.SocketServerTest > testNoOpActionResponseWithThrottledChannelWhereThrottlingInProgress STARTED

kafka.network.SocketServerTest > testNoOpActionResponseWithThrottledChannelWhereThrottlingInProgress PASSED

kafka.network.DynamicConnectionQuotaTest > testDynamicConnectionQuota STARTED

kafka.network.DynamicConnectionQuotaTest > testDynamicConnectionQuota PASSED

kafka.network.DynamicConnectionQuotaTest > testDynamicListenerConnectionQuota STARTED

kafka.network.DynamicConnectionQuotaTest > testDynamicListenerConnectionQuota PASSED

kafka.integration.MetricsDuringTopicCreationDeletionTest > testMetricsDuringTopicCreateDelete STARTED

kafka.integration.MetricsDuringTopicCreationDeletionTest > testMetricsDuringTopicCreateDelete PASSED

kafka.integration.UncleanLeaderElectionTest > testTopicUncleanLeaderElectionEnable STARTED

kafka.integration.UncleanLeaderElectionTest > testTopicUncleanLeaderElectionEnable PASSED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabled STARTED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabled PASSED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionDisabled STARTED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionDisabled PASSED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionInvalidTopicOverride STARTED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionInvalidTopicOverride PASSED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabledByTopicOverride STARTED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabledByTopicOverride PASSED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionDisabledByTopicOverride STARTED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionDisabledByTopicOverride PASSED

kafka.integration.MinIsrConfigTest > testDefaultKafkaConfig STARTED

kafka.integration.MinIsrConfigTest > testDefaultKafkaConfig PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=true] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=true] PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=false] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=false] PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=true] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=true] PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=false] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=false] PASSED

2370 tests completed, 1 failed, 2 skipped

> Task :core:test FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 44m 51s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #554

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

Changes:

[jason] MINOR: Work around OpenJDK 11 javadocs issue. (#6747)

------------------------------------------
[...truncated 2.46 MB...]
org.apache.kafka.connect.runtime.distributed.DistributedHerderTest > testJoinLeaderCatchUpFails PASSED

org.apache.kafka.connect.runtime.distributed.DistributedHerderTest > testInconsistentConfigs STARTED

org.apache.kafka.connect.runtime.distributed.DistributedHerderTest > testInconsistentConfigs PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignmentSingleTaskConnectors[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignmentSingleTaskConnectors[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupFollower[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupFollower[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testMetadata[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testMetadata[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment1[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment1[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment2[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment2[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testJoinLeaderCannotAssign[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testJoinLeaderCannotAssign[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testRejoinGroup[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testRejoinGroup[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupLeader[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupLeader[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignmentSingleTaskConnectors[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignmentSingleTaskConnectors[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupFollower[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupFollower[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testMetadata[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testMetadata[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment1[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment1[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment2[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment2[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testJoinLeaderCannotAssign[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testJoinLeaderCannotAssign[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testRejoinGroup[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testRejoinGroup[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupLeader[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupLeader[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testMetadataWithExistingAssignmentButOlderProtocolSelection[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testMetadataWithExistingAssignmentButOlderProtocolSelection[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testMetadataWithExistingAssignment[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testMetadataWithExistingAssignment[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testTaskAssignmentWhenWorkerBounces[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testTaskAssignmentWhenWorkerBounces[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testTaskAssignmentWhenWorkerJoins[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testTaskAssignmentWhenWorkerJoins[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testTaskAssignmentWhenWorkerLeavesPermanently[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testTaskAssignmentWhenWorkerLeavesPermanently[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testMetadata[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testMetadata[0] PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWhenWorkerLeavesPermanently STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWhenWorkerLeavesPermanently PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenLeaderBounces STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenLeaderBounces PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenWorkerBounces STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenWorkerBounces PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWhenWorkerBouncesBackButFinallyLeaves STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWhenWorkerBouncesBackButFinallyLeaves PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWhenWorkerBounces STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWhenWorkerBounces PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenWorkerJoins STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenWorkerJoins PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWithMoreThanOneCandidates STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWithMoreThanOneCandidates PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testAssignTasksWhenBalanced STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testAssignTasksWhenBalanced PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenWorkerLeavesPermanently STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenWorkerLeavesPermanently PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testAssignConnectorsWhenImbalanced STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testAssignConnectorsWhenImbalanced PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenConnectorsAreDeleted STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenConnectorsAreDeleted PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testAssignConnectorsWhenBalanced STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testAssignConnectorsWhenBalanced PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenSubsequentAssignmentAttemptFails STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenSubsequentAssignmentAttemptFails PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenFirstAssignmentAttemptFails STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenFirstAssignmentAttemptFails PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenLeaderLeavesPermanently STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenLeaderLeavesPermanently PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToCoopMetadata STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToCoopMetadata PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToEagerAssignment STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToEagerAssignment PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToCoopAssignment STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToCoopAssignment PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToCoopAssignment STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToCoopAssignment PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToEagerAssignment STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToEagerAssignment PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToEagerMetadata STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToEagerMetadata PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToEagerMetadata STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToEagerMetadata PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToCoopMetadata STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToCoopMetadata PASSED

org.apache.kafka.connect.runtime.WorkerTaskTest > standardStartup STARTED

org.apache.kafka.connect.runtime.WorkerTaskTest > standardStartup PASSED

org.apache.kafka.connect.runtime.WorkerTaskTest > stopBeforeStarting STARTED

org.apache.kafka.connect.runtime.WorkerTaskTest > stopBeforeStarting PASSED

org.apache.kafka.connect.runtime.WorkerTaskTest > cancelBeforeStopping STARTED

org.apache.kafka.connect.runtime.WorkerTaskTest > cancelBeforeStopping PASSED

org.apache.kafka.connect.runtime.WorkerTaskTest > updateMetricsOnListenerEventsForStartupPauseResumeAndShutdown STARTED

org.apache.kafka.connect.runtime.WorkerTaskTest > updateMetricsOnListenerEventsForStartupPauseResumeAndShutdown PASSED

org.apache.kafka.connect.runtime.WorkerTaskTest > updateMetricsOnListenerEventsForStartupPauseResumeAndFailure STARTED

org.apache.kafka.connect.runtime.WorkerTaskTest > updateMetricsOnListenerEventsForStartupPauseResumeAndFailure PASSED

org.apache.kafka.connect.connector.policy.NoneConnectorClientConfigOverridePolicyTest > testNoOverrides STARTED

org.apache.kafka.connect.connector.policy.NoneConnectorClientConfigOverridePolicyTest > testNoOverrides PASSED

org.apache.kafka.connect.connector.policy.NoneConnectorClientConfigOverridePolicyTest > testWithOverrides STARTED

org.apache.kafka.connect.connector.policy.NoneConnectorClientConfigOverridePolicyTest > testWithOverrides PASSED

org.apache.kafka.connect.connector.policy.PrincipalConnectorClientConfigOverridePolicyTest > testPrincipalPlusOtherConfigs STARTED

org.apache.kafka.connect.connector.policy.PrincipalConnectorClientConfigOverridePolicyTest > testPrincipalPlusOtherConfigs PASSED

org.apache.kafka.connect.connector.policy.PrincipalConnectorClientConfigOverridePolicyTest > testPrincipalOnly STARTED

org.apache.kafka.connect.connector.policy.PrincipalConnectorClientConfigOverridePolicyTest > testPrincipalOnly PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 40m 57s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #553

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

Changes:

[rhauch] KAFKA-8265: Fix config name to match KIP-458. (#6755)

[github] MINOR: Bump version to 2.4.0-SNAPSHOT (#6774)

------------------------------------------
[...truncated 2.50 MB...]
org.apache.kafka.connect.runtime.distributed.DistributedHerderTest > testAccessors PASSED

org.apache.kafka.connect.runtime.distributed.DistributedHerderTest > testPutConnectorConfig STARTED

org.apache.kafka.connect.runtime.distributed.DistributedHerderTest > testPutConnectorConfig PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignmentSingleTaskConnectors[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignmentSingleTaskConnectors[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupFollower[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupFollower[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testMetadata[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testMetadata[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment1[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment1[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment2[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment2[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testJoinLeaderCannotAssign[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testJoinLeaderCannotAssign[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testRejoinGroup[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testRejoinGroup[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupLeader[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupLeader[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignmentSingleTaskConnectors[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignmentSingleTaskConnectors[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupFollower[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupFollower[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testMetadata[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testMetadata[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment1[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment1[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment2[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testLeaderPerformAssignment2[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testJoinLeaderCannotAssign[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testJoinLeaderCannotAssign[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testRejoinGroup[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testRejoinGroup[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupLeader[1] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorTest > testNormalJoinGroupLeader[1] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testMetadataWithExistingAssignmentButOlderProtocolSelection[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testMetadataWithExistingAssignmentButOlderProtocolSelection[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testMetadataWithExistingAssignment[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testMetadataWithExistingAssignment[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testTaskAssignmentWhenWorkerBounces[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testTaskAssignmentWhenWorkerBounces[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testTaskAssignmentWhenWorkerJoins[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testTaskAssignmentWhenWorkerJoins[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testTaskAssignmentWhenWorkerLeavesPermanently[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testTaskAssignmentWhenWorkerLeavesPermanently[0] PASSED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testMetadata[0] STARTED

org.apache.kafka.connect.runtime.distributed.WorkerCoordinatorIncrementalTest > testMetadata[0] PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWhenWorkerLeavesPermanently STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWhenWorkerLeavesPermanently PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenLeaderBounces STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenLeaderBounces PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenWorkerBounces STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenWorkerBounces PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWhenWorkerBouncesBackButFinallyLeaves STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWhenWorkerBouncesBackButFinallyLeaves PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWhenWorkerBounces STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWhenWorkerBounces PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenWorkerJoins STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenWorkerJoins PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWithMoreThanOneCandidates STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testLostAssignmentHandlingWithMoreThanOneCandidates PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testAssignTasksWhenBalanced STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testAssignTasksWhenBalanced PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenWorkerLeavesPermanently STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenWorkerLeavesPermanently PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testAssignConnectorsWhenImbalanced STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testAssignConnectorsWhenImbalanced PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenConnectorsAreDeleted STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenConnectorsAreDeleted PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testAssignConnectorsWhenBalanced STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testAssignConnectorsWhenBalanced PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenSubsequentAssignmentAttemptFails STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenSubsequentAssignmentAttemptFails PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenFirstAssignmentAttemptFails STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenFirstAssignmentAttemptFails PASSED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenLeaderLeavesPermanently STARTED

org.apache.kafka.connect.runtime.distributed.IncrementalCooperativeAssignorTest > testTaskAssignmentWhenLeaderLeavesPermanently PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToCoopMetadata STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToCoopMetadata PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToEagerAssignment STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToEagerAssignment PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToCoopAssignment STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToCoopAssignment PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToCoopAssignment STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToCoopAssignment PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToEagerAssignment STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToEagerAssignment PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToEagerMetadata STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testCoopToEagerMetadata PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToEagerMetadata STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToEagerMetadata PASSED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToCoopMetadata STARTED

org.apache.kafka.connect.runtime.distributed.ConnectProtocolCompatibilityTest > testEagerToCoopMetadata PASSED

org.apache.kafka.connect.runtime.WorkerTaskTest > standardStartup STARTED

org.apache.kafka.connect.runtime.WorkerTaskTest > standardStartup PASSED

org.apache.kafka.connect.runtime.WorkerTaskTest > stopBeforeStarting STARTED

org.apache.kafka.connect.runtime.WorkerTaskTest > stopBeforeStarting PASSED

org.apache.kafka.connect.runtime.WorkerTaskTest > cancelBeforeStopping STARTED

org.apache.kafka.connect.runtime.WorkerTaskTest > cancelBeforeStopping PASSED

org.apache.kafka.connect.runtime.WorkerTaskTest > updateMetricsOnListenerEventsForStartupPauseResumeAndShutdown STARTED

org.apache.kafka.connect.runtime.WorkerTaskTest > updateMetricsOnListenerEventsForStartupPauseResumeAndShutdown PASSED

org.apache.kafka.connect.runtime.WorkerTaskTest > updateMetricsOnListenerEventsForStartupPauseResumeAndFailure STARTED

org.apache.kafka.connect.runtime.WorkerTaskTest > updateMetricsOnListenerEventsForStartupPauseResumeAndFailure PASSED

org.apache.kafka.connect.connector.policy.NoneConnectorClientConfigOverridePolicyTest > testNoOverrides STARTED

org.apache.kafka.connect.connector.policy.NoneConnectorClientConfigOverridePolicyTest > testNoOverrides PASSED

org.apache.kafka.connect.connector.policy.NoneConnectorClientConfigOverridePolicyTest > testWithOverrides STARTED

org.apache.kafka.connect.connector.policy.NoneConnectorClientConfigOverridePolicyTest > testWithOverrides PASSED

org.apache.kafka.connect.connector.policy.PrincipalConnectorClientConfigOverridePolicyTest > testPrincipalPlusOtherConfigs STARTED

org.apache.kafka.connect.connector.policy.PrincipalConnectorClientConfigOverridePolicyTest > testPrincipalPlusOtherConfigs PASSED

org.apache.kafka.connect.connector.policy.PrincipalConnectorClientConfigOverridePolicyTest > testPrincipalOnly STARTED

org.apache.kafka.connect.connector.policy.PrincipalConnectorClientConfigOverridePolicyTest > testPrincipalOnly PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 44m 5s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #552

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

Changes:

[jason] KAFKA-8316; Remove deprecated usage of Slf4jRequestLog,

------------------------------------------
[...truncated 2.45 MB...]
org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldRequireCustomTopicNameIfNotDefaultFactoryTopicNameWithDefaultTimestamp STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldRequireCustomTopicNameIfNotDefaultFactoryTopicNameWithDefaultTimestamp PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldNotAllowToCreateTopicWithNullTopicNameWithNullKey STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldNotAllowToCreateTopicWithNullTopicNameWithNullKey PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateNullKeyConsumerRecordWithOtherTopicNameAndTimestampWithTimetamp STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateNullKeyConsumerRecordWithOtherTopicNameAndTimestampWithTimetamp PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateConsumerRecordWithTimestamp STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateConsumerRecordWithTimestamp PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldNotAllowToCreateTopicWithNullHeaders STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldNotAllowToCreateTopicWithNullHeaders PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldNotAllowToCreateTopicWithNullTopicNameWithDefaultTimestamp STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldNotAllowToCreateTopicWithNullTopicNameWithDefaultTimestamp PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldRequireCustomTopicNameIfNotDefaultFactoryTopicName STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldRequireCustomTopicNameIfNotDefaultFactoryTopicName PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldRequireCustomTopicNameIfNotDefaultFactoryTopicNameWithNullKey STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldRequireCustomTopicNameIfNotDefaultFactoryTopicNameWithNullKey PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateConsumerRecord STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateConsumerRecord PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateNullKeyConsumerRecord STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateNullKeyConsumerRecord PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateConsumerRecordWithOtherTopicName STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateConsumerRecordWithOtherTopicName PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldAdvanceTime STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldAdvanceTime PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldNotAllowToCreateTopicWithNullTopicNameWithKeyValuePairs STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldNotAllowToCreateTopicWithNullTopicNameWithKeyValuePairs PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldRequireCustomTopicNameIfNotDefaultFactoryTopicNameWithKeyValuePairsAndCustomTimestamps STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldRequireCustomTopicNameIfNotDefaultFactoryTopicNameWithKeyValuePairsAndCustomTimestamps PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldRequireCustomTopicNameIfNotDefaultFactoryTopicNameWithKeyValuePairs STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldRequireCustomTopicNameIfNotDefaultFactoryTopicNameWithKeyValuePairs PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateConsumerRecordWithOtherTopicNameAndTimestamp STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateConsumerRecordWithOtherTopicNameAndTimestamp PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldNotAllowToCreateTopicWithNullTopicNameWithKeyValuePairsAndCustomTimestamps STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldNotAllowToCreateTopicWithNullTopicNameWithKeyValuePairsAndCustomTimestamps PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldNotAllowToCreateTopicWithNullTopicName STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldNotAllowToCreateTopicWithNullTopicName PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateConsumerRecordsFromKeyValuePairsWithCustomTimestampAndIncrementsAndNotAdvanceTime STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateConsumerRecordsFromKeyValuePairsWithCustomTimestampAndIncrementsAndNotAdvanceTime PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateNullKeyConsumerRecordWithTimestampWithTimestamp STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateNullKeyConsumerRecordWithTimestampWithTimestamp PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldRequireCustomTopicNameIfNotDefaultFactoryTopicNameWithNullKeyAndDefaultTimestamp STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldRequireCustomTopicNameIfNotDefaultFactoryTopicNameWithNullKeyAndDefaultTimestamp PASSED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateConsumerRecordsFromKeyValuePairsWithTimestampAndIncrements STARTED

org.apache.kafka.streams.test.ConsumerRecordFactoryTest > shouldCreateConsumerRecordsFromKeyValuePairsWithTimestampAndIncrements PASSED

org.apache.kafka.streams.MockProcessorContextTest > shouldStoreAndReturnStateStores STARTED

org.apache.kafka.streams.MockProcessorContextTest > shouldStoreAndReturnStateStores PASSED

org.apache.kafka.streams.MockProcessorContextTest > shouldCaptureOutputRecordsUsingTo STARTED

org.apache.kafka.streams.MockProcessorContextTest > shouldCaptureOutputRecordsUsingTo PASSED

org.apache.kafka.streams.MockProcessorContextTest > shouldCaptureOutputRecords STARTED

org.apache.kafka.streams.MockProcessorContextTest > shouldCaptureOutputRecords PASSED

org.apache.kafka.streams.MockProcessorContextTest > fullConstructorShouldSetAllExpectedAttributes STARTED

org.apache.kafka.streams.MockProcessorContextTest > fullConstructorShouldSetAllExpectedAttributes PASSED

org.apache.kafka.streams.MockProcessorContextTest > shouldCaptureCommitsAndAllowReset STARTED

org.apache.kafka.streams.MockProcessorContextTest > shouldCaptureCommitsAndAllowReset PASSED

org.apache.kafka.streams.MockProcessorContextTest > shouldThrowIfForwardedWithDeprecatedChildName STARTED

org.apache.kafka.streams.MockProcessorContextTest > shouldThrowIfForwardedWithDeprecatedChildName PASSED

org.apache.kafka.streams.MockProcessorContextTest > shouldThrowIfForwardedWithDeprecatedChildIndex STARTED

org.apache.kafka.streams.MockProcessorContextTest > shouldThrowIfForwardedWithDeprecatedChildIndex PASSED

org.apache.kafka.streams.MockProcessorContextTest > shouldCaptureApplicationAndRecordMetadata STARTED

org.apache.kafka.streams.MockProcessorContextTest > shouldCaptureApplicationAndRecordMetadata PASSED

org.apache.kafka.streams.MockProcessorContextTest > shouldCaptureRecordsOutputToChildByName STARTED

org.apache.kafka.streams.MockProcessorContextTest > shouldCaptureRecordsOutputToChildByName PASSED

org.apache.kafka.streams.MockProcessorContextTest > shouldCapturePunctuator STARTED

org.apache.kafka.streams.MockProcessorContextTest > shouldCapturePunctuator PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldReturnIsOpen STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldReturnIsOpen PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldDeleteAndReturnPlainValue STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldDeleteAndReturnPlainValue PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldReturnName STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldReturnName PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldPutWithUnknownTimestamp STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldPutWithUnknownTimestamp PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldPutAllWithUnknownTimestamp STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldPutAllWithUnknownTimestamp PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldReturnIsPersistent STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldReturnIsPersistent PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldPutIfAbsentWithUnknownTimestamp STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldPutIfAbsentWithUnknownTimestamp PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldForwardClose STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldForwardClose PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldForwardFlush STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldForwardFlush PASSED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldForwardInit STARTED

org.apache.kafka.streams.internals.KeyValueStoreFacadeTest > shouldForwardInit PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldReturnIsOpen STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldReturnIsOpen PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldReturnName STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldReturnName PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldPutWithUnknownTimestamp STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldPutWithUnknownTimestamp PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldPutWindowStartTimestampWithUnknownTimestamp STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldPutWindowStartTimestampWithUnknownTimestamp PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldReturnIsPersistent STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldReturnIsPersistent PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldForwardClose STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldForwardClose PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldForwardFlush STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldForwardFlush PASSED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldForwardInit STARTED

org.apache.kafka.streams.internals.WindowStoreFacadeTest > shouldForwardInit PASSED

org.apache.kafka.streams.MockTimeTest > shouldGetNanosAsMillis STARTED

org.apache.kafka.streams.MockTimeTest > shouldGetNanosAsMillis PASSED

org.apache.kafka.streams.MockTimeTest > shouldSetStartTime STARTED

org.apache.kafka.streams.MockTimeTest > shouldSetStartTime PASSED

org.apache.kafka.streams.MockTimeTest > shouldNotAllowNegativeSleep STARTED

org.apache.kafka.streams.MockTimeTest > shouldNotAllowNegativeSleep PASSED

org.apache.kafka.streams.MockTimeTest > shouldAdvanceTimeOnSleep STARTED

org.apache.kafka.streams.MockTimeTest > shouldAdvanceTimeOnSleep PASSED

> Task :streams:examples:test

org.apache.kafka.streams.examples.wordcount.WordCountProcessorTest > test STARTED

org.apache.kafka.streams.examples.wordcount.WordCountProcessorTest > test PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 46m 2s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #551

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

Changes:

[jason] MINOR: Add log when the consumer does not send an offset commit due to

[github] KAFKA-8381; Disable hostname validation when verifying inter-broker SSL

------------------------------------------
[...truncated 2.46 MB...]
org.apache.kafka.connect.data.ValuesTest > shouldConvertMapWithStringKeysAndIntegerValues PASSED

org.apache.kafka.connect.data.ValuesTest > shouldConvertDateValues STARTED

org.apache.kafka.connect.data.ValuesTest > shouldConvertDateValues PASSED

org.apache.kafka.connect.data.ValuesTest > shouldFailToParseInvalidBooleanValueString STARTED

org.apache.kafka.connect.data.ValuesTest > shouldFailToParseInvalidBooleanValueString PASSED

org.apache.kafka.connect.data.ValuesTest > shouldConvertTimestampValues STARTED

org.apache.kafka.connect.data.ValuesTest > shouldConvertTimestampValues PASSED

org.apache.kafka.connect.data.ValuesTest > shouldConvertNullValue STARTED

org.apache.kafka.connect.data.ValuesTest > shouldConvertNullValue PASSED

org.apache.kafka.connect.data.ValuesTest > shouldConvertTimeValues STARTED

org.apache.kafka.connect.data.ValuesTest > shouldConvertTimeValues PASSED

org.apache.kafka.connect.data.ValuesTest > shouldFailToParseStringOfMalformedMap STARTED

org.apache.kafka.connect.data.ValuesTest > shouldFailToParseStringOfMalformedMap PASSED

org.apache.kafka.connect.data.ValuesTest > shouldParseStringOfMapWithShortValuesWithoutWhitespaceAsMap STARTED

org.apache.kafka.connect.data.ValuesTest > shouldParseStringOfMapWithShortValuesWithoutWhitespaceAsMap PASSED

org.apache.kafka.connect.data.ValuesTest > shouldConvertListWithStringValues STARTED

org.apache.kafka.connect.data.ValuesTest > shouldConvertListWithStringValues PASSED

org.apache.kafka.connect.data.ValuesTest > shouldParseStringsWithEscapedDelimiters STARTED

org.apache.kafka.connect.data.ValuesTest > shouldParseStringsWithEscapedDelimiters PASSED

org.apache.kafka.connect.data.ValuesTest > shouldConvertStringOfListWithOnlyNumericElementTypesIntoListOfLargestNumericType STARTED

org.apache.kafka.connect.data.ValuesTest > shouldConvertStringOfListWithOnlyNumericElementTypesIntoListOfLargestNumericType PASSED

org.apache.kafka.connect.data.ValuesTest > shouldParseStringOfMapWithIntValuesWithWhitespaceAsMap STARTED

org.apache.kafka.connect.data.ValuesTest > shouldParseStringOfMapWithIntValuesWithWhitespaceAsMap PASSED

org.apache.kafka.connect.data.ValuesTest > shouldConvertListWithIntegerValues STARTED

org.apache.kafka.connect.data.ValuesTest > shouldConvertListWithIntegerValues PASSED

org.apache.kafka.connect.data.ValuesTest > shouldConvertStringOfListWithMixedElementTypesIntoListWithDifferentElementTypes STARTED

org.apache.kafka.connect.data.ValuesTest > shouldConvertStringOfListWithMixedElementTypesIntoListWithDifferentElementTypes PASSED

org.apache.kafka.connect.data.ValuesTest > shouldEscapeStringsWithEmbeddedQuotesAndBackslashes STARTED

org.apache.kafka.connect.data.ValuesTest > shouldEscapeStringsWithEmbeddedQuotesAndBackslashes PASSED

org.apache.kafka.connect.data.ValuesTest > shouldParseStringListWithMultipleElementTypesAndReturnListWithNoSchema STARTED

org.apache.kafka.connect.data.ValuesTest > shouldParseStringListWithMultipleElementTypesAndReturnListWithNoSchema PASSED

org.apache.kafka.connect.data.ValuesTest > shouldFailToConvertToListFromStringWithNonCommonElementTypeAndBlankElement STARTED

org.apache.kafka.connect.data.ValuesTest > shouldFailToConvertToListFromStringWithNonCommonElementTypeAndBlankElement PASSED

org.apache.kafka.connect.data.ValuesTest > shouldParseStringsWithMultipleDelimiters STARTED

org.apache.kafka.connect.data.ValuesTest > shouldParseStringsWithMultipleDelimiters PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testStructEquality STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testStructEquality PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchMapValue STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchMapValue PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchStructWrongSchema STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchStructWrongSchema PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchMapSomeValues STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchMapSomeValues PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchBoolean STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchBoolean PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testFieldsOnStructSchema STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testFieldsOnStructSchema PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchArray STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchArray PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchBytes STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchBytes PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchFloat STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchFloat PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchInt16 STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchInt16 PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchInt32 STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchInt32 PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchInt64 STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchInt64 PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testMapEquality STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testMapEquality PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testPrimitiveEquality STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testPrimitiveEquality PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchTimestamp STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchTimestamp PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchStructWrongNestedSchema STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchStructWrongNestedSchema PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchDecimal STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchDecimal PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testArrayDefaultValueEquality STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testArrayDefaultValueEquality PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testEmptyStruct STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testEmptyStruct PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchMapSomeKeys STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchMapSomeKeys PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchArraySomeMatch STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchArraySomeMatch PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchDate STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchDate PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchInt8 STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchInt8 PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchTime STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchTime PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchDouble STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchDouble PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchMapKey STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchMapKey PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchString STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMismatchString PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMatchingType STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMatchingType PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testArrayEquality STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testArrayEquality PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testFieldsOnlyValidForStructs STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testFieldsOnlyValidForStructs PASSED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMatchingLogicalType STARTED

org.apache.kafka.connect.data.ConnectSchemaTest > testValidateValueMatchingLogicalType PASSED

org.apache.kafka.connect.source.SourceRecordTest > shouldDuplicateRecordAndCloneHeaders STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldDuplicateRecordAndCloneHeaders PASSED

org.apache.kafka.connect.source.SourceRecordTest > shouldDuplicateRecordUsingNewHeaders STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldDuplicateRecordUsingNewHeaders PASSED

org.apache.kafka.connect.source.SourceRecordTest > shouldModifyRecordHeader STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldModifyRecordHeader PASSED

org.apache.kafka.connect.source.SourceRecordTest > shouldCreateSinkRecordWithHeaders STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldCreateSinkRecordWithHeaders PASSED

org.apache.kafka.connect.source.SourceRecordTest > shouldCreateSinkRecordWithEmtpyHeaders STARTED

org.apache.kafka.connect.source.SourceRecordTest > shouldCreateSinkRecordWithEmtpyHeaders PASSED

org.apache.kafka.connect.connector.ConnectorReconfigurationTest > testReconfigureStopException STARTED

org.apache.kafka.connect.connector.ConnectorReconfigurationTest > testReconfigureStopException PASSED

org.apache.kafka.connect.connector.ConnectorReconfigurationTest > testDefaultReconfigure STARTED

org.apache.kafka.connect.connector.ConnectorReconfigurationTest > testDefaultReconfigure PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 45m 1s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #550

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

Changes:

[github] KAFKA-8290: Close producer for zombie task (#6636)

------------------------------------------
[...truncated 2.46 MB...]
org.apache.kafka.streams.scala.kstream.JoinedTest > Create a Joined should create a Joined with Serdes and repartition topic name PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > filter a KTable should filter records satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > filter a KTable should filter records satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > filterNot a KTable should filter records not satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > filterNot a KTable should filter records not satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables should join correctly records STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables should join correctly records PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables with a Materialized should join correctly records and state store STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables with a Materialized should join correctly records and state store PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > windowed KTable#suppress should correctly suppress results using Suppressed.untilTimeLimit STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > windowed KTable#suppress should correctly suppress results using Suppressed.untilTimeLimit PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > windowed KTable#suppress should correctly suppress results using Suppressed.untilWindowCloses STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > windowed KTable#suppress should correctly suppress results using Suppressed.untilWindowCloses PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > session windowed KTable#suppress should correctly suppress results using Suppressed.untilWindowCloses STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > session windowed KTable#suppress should correctly suppress results using Suppressed.untilWindowCloses PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > non-windowed KTable#suppress should correctly suppress results using Suppressed.untilTimeLimit STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > non-windowed KTable#suppress should correctly suppress results using Suppressed.untilTimeLimit PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialized should create a Materialized with Serdes STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialized should create a Materialized with Serdes PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a store name should create a Materialized with Serdes and a store name STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a store name should create a Materialized with Serdes and a store name PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a window store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a window store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a key value store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a key value store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a session store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a session store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > filter a KStream should filter records satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > filter a KStream should filter records satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > filterNot a KStream should filter records not satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > filterNot a KStream should filter records not satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > foreach a KStream should run foreach actions on records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > foreach a KStream should run foreach actions on records PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > peek a KStream should run peek actions on records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > peek a KStream should run peek actions on records PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > selectKey a KStream should select a new key STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > selectKey a KStream should select a new key PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > join 2 KStreams should join correctly records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > join 2 KStreams should join correctly records PASSED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsMaterialized STARTED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsMaterialized PASSED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsJava STARTED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsJava PASSED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWords STARTED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWords PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaJoin STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaJoin PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaSimple STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaSimple PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaAggregate STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaAggregate PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaProperties STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaProperties PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaTransform STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaTransform PASSED

> Task :log4j-appender:test

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithSyncSendWithoutIgnoringExceptionsShouldNotThrowException STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithSyncSendWithoutIgnoringExceptionsShouldNotThrowException PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithRealProducerConfigWithSyncSendAndNotIgnoringExceptionsShouldThrowException STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithRealProducerConfigWithSyncSendAndNotIgnoringExceptionsShouldThrowException PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppends STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppends PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSetSaslMechanism STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSetSaslMechanism PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testJaasConfigNotSet STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testJaasConfigNotSet PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testKafkaLog4jConfigs STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testKafkaLog4jConfigs PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithSyncSendAndSimulateProducerFailShouldThrowException STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithSyncSendAndSimulateProducerFailShouldThrowException PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithRealProducerConfigWithSyncSendShouldNotThrowException STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppendsWithRealProducerConfigWithSyncSendShouldNotThrowException PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSaslMechanismNotSet STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSaslMechanismNotSet PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSetJaasConfig STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testSetJaasConfig PASSED

> Task :connect:file:test

org.apache.kafka.connect.file.FileStreamSourceTaskTest > testNormalLifecycle STARTED

org.apache.kafka.connect.file.FileStreamSourceTaskTest > testNormalLifecycle PASSED

org.apache.kafka.connect.file.FileStreamSourceTaskTest > testBatchSize STARTED

org.apache.kafka.connect.file.FileStreamSourceTaskTest > testBatchSize PASSED

org.apache.kafka.connect.file.FileStreamSourceTaskTest > testMissingFile STARTED

org.apache.kafka.connect.file.FileStreamSourceTaskTest > testMissingFile PASSED

org.apache.kafka.connect.file.FileStreamSinkTaskTest > testPutFlush STARTED

org.apache.kafka.connect.file.FileStreamSinkTaskTest > testPutFlush PASSED

org.apache.kafka.connect.file.FileStreamSinkTaskTest > testStart STARTED

org.apache.kafka.connect.file.FileStreamSinkTaskTest > testStart PASSED

org.apache.kafka.connect.file.FileStreamSinkConnectorTest > testSinkTasks STARTED

org.apache.kafka.connect.file.FileStreamSinkConnectorTest > testSinkTasks PASSED

org.apache.kafka.connect.file.FileStreamSinkConnectorTest > testTaskClass STARTED

org.apache.kafka.connect.file.FileStreamSinkConnectorTest > testTaskClass PASSED

org.apache.kafka.connect.file.FileStreamSinkConnectorTest > testConnectorConfigValidation STARTED

org.apache.kafka.connect.file.FileStreamSinkConnectorTest > testConnectorConfigValidation PASSED

org.apache.kafka.connect.file.FileStreamSinkConnectorTest > testSinkTasksStdout STARTED

org.apache.kafka.connect.file.FileStreamSinkConnectorTest > testSinkTasksStdout PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testBlankTopic STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testBlankTopic PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testSourceTasks STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testSourceTasks PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testMissingTopic STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testMissingTopic PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testSourceTasksStdin STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testSourceTasksStdin PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testTaskClass STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testTaskClass PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testInvalidBatchSize STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testInvalidBatchSize PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testConnectorConfigValidation STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testConnectorConfigValidation PASSED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testMultipleSourcesInvalid STARTED

org.apache.kafka.connect.file.FileStreamSourceConnectorTest > testMultipleSourcesInvalid PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 30m 46s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #549

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

Changes:

[wangguoz] KAFKA-6474: remove KStreamTestDriver (#6732)

[jason] MINOR: Update command options for kafka-console-consumer.sh in

------------------------------------------
[...truncated 2.46 MB...]
org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueAndTimestampIsEqualWithNullForCompareValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueAndTimestampIsEqualWithNullForCompareValueTimestampWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareKeyValue STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareKeyValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentWithNullForCompareKeyValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentWithNullForCompareKeyValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentForCompareKeyValueWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentForCompareKeyValueWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareKeyValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareKeyValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfTimestampIsDifferentForCompareValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfTimestampIsDifferentForCompareValueTimestampWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueIsEqualForCompareKeyValue STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueIsEqualForCompareKeyValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullProducerRecordForCompareKeyValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullProducerRecordForCompareKeyValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueIsEqualWithNullForCompareKeyValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueIsEqualWithNullForCompareKeyValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueAndTimestampIsEqualForCompareValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueAndTimestampIsEqualForCompareValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullExpectedRecordForCompareKeyValue STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullExpectedRecordForCompareKeyValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentForCompareValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentForCompareValueTimestampWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReversForCompareKeyValue STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReversForCompareKeyValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullExpectedRecordForCompareKeyValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullExpectedRecordForCompareKeyValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentForCompareValueWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentForCompareValueWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueIsEqualForCompareValue STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueIsEqualForCompareValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullProducerRecordWithExpectedRecordForCompareKeyValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullProducerRecordWithExpectedRecordForCompareKeyValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentForCompareKeyValue STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentForCompareKeyValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullProducerRecordWithExpectedRecordForCompareKeyValue STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullProducerRecordWithExpectedRecordForCompareKeyValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentWithNullForCompareKeyValueWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentWithNullForCompareKeyValueWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueAndTimestampIsEqualForCompareKeyValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueAndTimestampIsEqualForCompareKeyValueTimestampWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueIsEqualWithNullForCompareValue STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueIsEqualWithNullForCompareValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueAndTimestampIsEqualWithNullForCompareValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueAndTimestampIsEqualWithNullForCompareValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareValueTimestampWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareValueWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareValueWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentWithNullReversForCompareKeyValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentWithNullReversForCompareKeyValueTimestampWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentWithNullReversForCompareKeyValue STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentWithNullReversForCompareKeyValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueIsEqualForCompareKeyValueWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueIsEqualForCompareKeyValueWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentForCompareKeyValueWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentForCompareKeyValueWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentForCompareValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentForCompareValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullProducerRecordForCompareValue STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullProducerRecordForCompareValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentForCompareKeyValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentForCompareKeyValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentForCompareKeyValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentForCompareKeyValueTimestampWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueIsEqualWithNullForCompareValueWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueIsEqualWithNullForCompareValueWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReverseForCompareValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReverseForCompareValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReverseForCompareValue STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReverseForCompareValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfTimestampIsDifferentForCompareValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfTimestampIsDifferentForCompareValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueAndTimestampIsEqualWithNullForCompareKeyValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueAndTimestampIsEqualWithNullForCompareKeyValueTimestampWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareKeyValueWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareKeyValueWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentForCompareKeyValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentForCompareKeyValueTimestampWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullProducerRecordWithExpectedRecordForCompareValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullProducerRecordWithExpectedRecordForCompareValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullExpectedRecordForCompareValue STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullExpectedRecordForCompareValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReversForCompareKeyValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReversForCompareKeyValueTimestampWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullProducerRecordForCompareKeyValue STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldNotAllowNullProducerRecordForCompareKeyValue PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReversForCompareKeyValueWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReversForCompareKeyValueWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueAndTimestampIsEqualForCompareKeyValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueAndTimestampIsEqualForCompareKeyValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareKeyValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullForCompareKeyValueTimestampWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentWithNullReversForCompareKeyValueWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentWithNullReversForCompareKeyValueWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueIsEqualWithNullForCompareKeyValueWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfKeyAndValueIsEqualWithNullForCompareKeyValueWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentWithNullForCompareKeyValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfKeyIsDifferentWithNullForCompareKeyValueTimestampWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentForCompareKeyValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentForCompareKeyValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueAndTimestampIsEqualForCompareValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldPassIfValueAndTimestampIsEqualForCompareValueTimestampWithProducerRecord PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReversForCompareKeyValueTimestamp STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReversForCompareKeyValueTimestamp PASSED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReverseForCompareValueTimestampWithProducerRecord STARTED

org.apache.kafka.streams.test.OutputVerifierTest > shouldFailIfValueIsDifferentWithNullReverseForCompareValueTimestampWithProducerRecord PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 26m 40s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #548

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/kafka-trunk-jdk11/548/display/redirect>

------------------------------------------
[...truncated 2.46 MB...]
kafka.zk.KafkaZkClientTest > testRegisterBrokerInfo PASSED

kafka.zk.KafkaZkClientTest > testRetryRegisterBrokerInfo STARTED

kafka.zk.KafkaZkClientTest > testRetryRegisterBrokerInfo PASSED

kafka.zk.KafkaZkClientTest > testConsumerOffsetPath STARTED

kafka.zk.KafkaZkClientTest > testConsumerOffsetPath PASSED

kafka.zk.KafkaZkClientTest > testDeleteRecursiveWithControllerEpochVersionCheck STARTED

kafka.zk.KafkaZkClientTest > testDeleteRecursiveWithControllerEpochVersionCheck PASSED

kafka.zk.KafkaZkClientTest > testControllerManagementMethods STARTED

kafka.zk.KafkaZkClientTest > testControllerManagementMethods PASSED

kafka.zk.KafkaZkClientTest > testTopicAssignmentMethods STARTED

kafka.zk.KafkaZkClientTest > testTopicAssignmentMethods PASSED

kafka.zk.KafkaZkClientTest > testPropagateIsrChanges STARTED

kafka.zk.KafkaZkClientTest > testPropagateIsrChanges PASSED

kafka.zk.KafkaZkClientTest > testControllerEpochMethods STARTED

kafka.zk.KafkaZkClientTest > testControllerEpochMethods PASSED

kafka.zk.KafkaZkClientTest > testDeleteRecursive STARTED

kafka.zk.KafkaZkClientTest > testDeleteRecursive PASSED

kafka.zk.KafkaZkClientTest > testGetTopicPartitionStates STARTED

kafka.zk.KafkaZkClientTest > testGetTopicPartitionStates PASSED

kafka.zk.KafkaZkClientTest > testCreateConfigChangeNotification STARTED

kafka.zk.KafkaZkClientTest > testCreateConfigChangeNotification PASSED

kafka.zk.KafkaZkClientTest > testDelegationTokenMethods STARTED

kafka.zk.KafkaZkClientTest > testDelegationTokenMethods PASSED

kafka.zk.ReassignPartitionsZNodeTest > testDecodeInvalidJson STARTED

kafka.zk.ReassignPartitionsZNodeTest > testDecodeInvalidJson PASSED

kafka.zk.ReassignPartitionsZNodeTest > testEncode STARTED

kafka.zk.ReassignPartitionsZNodeTest > testEncode PASSED

kafka.zk.ReassignPartitionsZNodeTest > testDecodeValidJson STARTED

kafka.zk.ReassignPartitionsZNodeTest > testDecodeValidJson PASSED

kafka.zk.LiteralAclStoreTest > shouldHaveCorrectPaths STARTED

kafka.zk.LiteralAclStoreTest > shouldHaveCorrectPaths PASSED

kafka.zk.LiteralAclStoreTest > shouldRoundTripChangeNode STARTED

kafka.zk.LiteralAclStoreTest > shouldRoundTripChangeNode PASSED

kafka.zk.LiteralAclStoreTest > shouldThrowFromEncodeOnNoneLiteral STARTED

kafka.zk.LiteralAclStoreTest > shouldThrowFromEncodeOnNoneLiteral PASSED

kafka.zk.LiteralAclStoreTest > shouldWriteChangesToTheWritePath STARTED

kafka.zk.LiteralAclStoreTest > shouldWriteChangesToTheWritePath PASSED

kafka.zk.LiteralAclStoreTest > shouldHaveCorrectPatternType STARTED

kafka.zk.LiteralAclStoreTest > shouldHaveCorrectPatternType PASSED

kafka.zk.LiteralAclStoreTest > shouldDecodeResourceUsingTwoPartLogic STARTED

kafka.zk.LiteralAclStoreTest > shouldDecodeResourceUsingTwoPartLogic PASSED

kafka.cluster.BrokerEndPointTest > testEndpointFromUri STARTED

kafka.cluster.BrokerEndPointTest > testEndpointFromUri PASSED

kafka.cluster.BrokerEndPointTest > testHashAndEquals STARTED

kafka.cluster.BrokerEndPointTest > testHashAndEquals PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV4WithNoRack STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV4WithNoRack PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonFutureVersion STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonFutureVersion PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV4WithNullRack STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV4WithNullRack PASSED

kafka.cluster.BrokerEndPointTest > testBrokerEndpointFromUri STARTED

kafka.cluster.BrokerEndPointTest > testBrokerEndpointFromUri PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV1 STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV1 PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV2 STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV2 PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV3 STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV3 PASSED

kafka.cluster.PartitionTest > testMakeLeaderDoesNotUpdateEpochCacheForOldFormats STARTED

kafka.cluster.PartitionTest > testMakeLeaderDoesNotUpdateEpochCacheForOldFormats PASSED

kafka.cluster.PartitionTest > testReadRecordEpochValidationForLeader STARTED

kafka.cluster.PartitionTest > testReadRecordEpochValidationForLeader PASSED

kafka.cluster.PartitionTest > testFetchOffsetForTimestampEpochValidationForFollower STARTED

kafka.cluster.PartitionTest > testFetchOffsetForTimestampEpochValidationForFollower PASSED

kafka.cluster.PartitionTest > testListOffsetIsolationLevels STARTED

kafka.cluster.PartitionTest > testListOffsetIsolationLevels PASSED

kafka.cluster.PartitionTest > testAppendRecordsAsFollowerBelowLogStartOffset STARTED

kafka.cluster.PartitionTest > testAppendRecordsAsFollowerBelowLogStartOffset PASSED

kafka.cluster.PartitionTest > testFetchLatestOffsetIncludesLeaderEpoch STARTED

kafka.cluster.PartitionTest > testFetchLatestOffsetIncludesLeaderEpoch PASSED

kafka.cluster.PartitionTest > testFetchOffsetSnapshotEpochValidationForFollower STARTED

kafka.cluster.PartitionTest > testFetchOffsetSnapshotEpochValidationForFollower PASSED

kafka.cluster.PartitionTest > testMonotonicOffsetsAfterLeaderChange STARTED

kafka.cluster.PartitionTest > testMonotonicOffsetsAfterLeaderChange PASSED

kafka.cluster.PartitionTest > testMakeFollowerWithNoLeaderIdChange STARTED

kafka.cluster.PartitionTest > testMakeFollowerWithNoLeaderIdChange PASSED

kafka.cluster.PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException STARTED

kafka.cluster.PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException PASSED

kafka.cluster.PartitionTest > testFollowerDoesNotJoinISRUntilCaughtUpToOffsetWithinCurrentLeaderEpoch STARTED

kafka.cluster.PartitionTest > testFollowerDoesNotJoinISRUntilCaughtUpToOffsetWithinCurrentLeaderEpoch PASSED

kafka.cluster.PartitionTest > testFetchOffsetSnapshotEpochValidationForLeader STARTED

kafka.cluster.PartitionTest > testFetchOffsetSnapshotEpochValidationForLeader PASSED

kafka.cluster.PartitionTest > testOffsetForLeaderEpochValidationForLeader STARTED

kafka.cluster.PartitionTest > testOffsetForLeaderEpochValidationForLeader PASSED

kafka.cluster.PartitionTest > testAtMinIsr STARTED

kafka.cluster.PartitionTest > testAtMinIsr PASSED

kafka.cluster.PartitionTest > testOffsetForLeaderEpochValidationForFollower STARTED

kafka.cluster.PartitionTest > testOffsetForLeaderEpochValidationForFollower PASSED

kafka.cluster.PartitionTest > testDelayedFetchAfterAppendRecords STARTED

kafka.cluster.PartitionTest > testDelayedFetchAfterAppendRecords PASSED

kafka.cluster.PartitionTest > testMakeLeaderUpdatesEpochCache STARTED

kafka.cluster.PartitionTest > testMakeLeaderUpdatesEpochCache PASSED

kafka.cluster.PartitionTest > testMaybeReplaceCurrentWithFutureReplicaDifferentBaseOffsets STARTED

kafka.cluster.PartitionTest > testMaybeReplaceCurrentWithFutureReplicaDifferentBaseOffsets PASSED

kafka.cluster.PartitionTest > testFetchOffsetForTimestampEpochValidationForLeader STARTED

kafka.cluster.PartitionTest > testFetchOffsetForTimestampEpochValidationForLeader PASSED

kafka.cluster.PartitionTest > testGetReplica STARTED

kafka.cluster.PartitionTest > testGetReplica PASSED

kafka.cluster.PartitionTest > testReadRecordEpochValidationForFollower STARTED

kafka.cluster.PartitionTest > testReadRecordEpochValidationForFollower PASSED

kafka.cluster.PartitionTest > testMaybeReplaceCurrentWithFutureReplica STARTED

kafka.cluster.PartitionTest > testMaybeReplaceCurrentWithFutureReplica PASSED

kafka.cluster.ReplicaTest > testCannotIncrementLogStartOffsetPastHighWatermark STARTED

kafka.cluster.ReplicaTest > testCannotIncrementLogStartOffsetPastHighWatermark PASSED

kafka.cluster.ReplicaTest > testSegmentDeletionWithHighWatermarkInitialization STARTED

kafka.cluster.ReplicaTest > testSegmentDeletionWithHighWatermarkInitialization PASSED

kafka.cluster.ReplicaTest > testCannotDeleteSegmentsAtOrAboveHighWatermark STARTED

kafka.cluster.ReplicaTest > testCannotDeleteSegmentsAtOrAboveHighWatermark PASSED

2366 tests completed, 1 failed, 4 skipped

> Task :core:test FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 2h 25m 14s
174 actionable tasks: 149 executed, 25 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #547

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

Changes:

[github] MINOR: Increase security test timeouts for transient failures (#6760)

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H28 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk11/ws/>
[WS-CLEANUP] Deleting project workspace...
[WS-CLEANUP] Deferred wipeout is used...
[WS-CLEANUP] Done
No credentials specified
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-trunk-jdk11/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision b52170372b26249c7c7e8604bbbdc3a792f092b2 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f b52170372b26249c7c7e8604bbbdc3a792f092b2
Commit message: "MINOR: Increase security test timeouts for transient failures (#6760)"
 > git rev-list --no-walk e00c0d316db01fbe5e57a4dfd54856c89e761b08 # timeout=10
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: No tool found matching GRADLE_4_10_2_HOME
[kafka-trunk-jdk11] $ /bin/bash -xe /tmp/jenkins6992417947282523320.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk11/ws/.gradle>
+ /bin/gradle
/tmp/jenkins6992417947282523320.sh: line 4: /bin/gradle: No such file or directory
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
ERROR: No tool found matching GRADLE_4_10_2_HOME
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #546

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

Changes:

[jason] MINOR: Fix typo in heartbeat request protocol definition (#6759)

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H28 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk11/ws/>
[WS-CLEANUP] Deleting project workspace...
[WS-CLEANUP] Deferred wipeout is used...
[WS-CLEANUP] Done
No credentials specified
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-trunk-jdk11/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision e00c0d316db01fbe5e57a4dfd54856c89e761b08 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f e00c0d316db01fbe5e57a4dfd54856c89e761b08
Commit message: "MINOR: Fix typo in heartbeat request protocol definition (#6759)"
 > git rev-list --no-walk a29a00531659864e053aff2019fde8202132c35b # timeout=10
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: No tool found matching GRADLE_4_10_2_HOME
[kafka-trunk-jdk11] $ /bin/bash -xe /tmp/jenkins2950428820892025020.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk11/ws/.gradle>
+ /bin/gradle
/tmp/jenkins2950428820892025020.sh: line 4: /bin/gradle: No such file or directory
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
ERROR: No tool found matching GRADLE_4_10_2_HOME
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #545

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

Changes:

[jason] MINOR: Fixed broken link to the IBM article about j-zerocopy (#6749)

[jason] KAFKA-8349; Add Windows batch files corresponding to

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk11/ws/>
[WS-CLEANUP] Deleting project workspace...
[WS-CLEANUP] Deferred wipeout is used...
[WS-CLEANUP] Done
No credentials specified
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-trunk-jdk11/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision a29a00531659864e053aff2019fde8202132c35b (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f a29a00531659864e053aff2019fde8202132c35b
Commit message: "KAFKA-8349; Add Windows batch files corresponding to kafka-delete-records.sh and kafka-log-dirs.sh (#6709)"
 > git rev-list --no-walk 9fa331b811d893a0d580e9136c1c7e1fa9774542 # timeout=10
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: No tool found matching GRADLE_4_10_2_HOME
[kafka-trunk-jdk11] $ /bin/bash -xe /tmp/jenkins3812518306870166613.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk11/ws/.gradle>
+ /bin/gradle
/tmp/jenkins3812518306870166613.sh: line 4: /bin/gradle: No such file or directory
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
ERROR: No tool found matching GRADLE_4_10_2_HOME
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #544

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

Changes:

[wangguoz] KAFKA-8225 & KIP-345 part-2: fencing static member instances with

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk11/ws/>
[WS-CLEANUP] Deleting project workspace...
[WS-CLEANUP] Deferred wipeout is used...
[WS-CLEANUP] Done
No credentials specified
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-trunk-jdk11/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
ERROR: Timeout after 10 minutes
ERROR: Error cloning remote repo 'origin'
hudson.plugins.git.GitException: Command "git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*" returned status code 128:
stdout: 
stderr: remote: Enumerating objects: 29, done.        
remote: Counting objects:   3% (1/29)           remote: Counting objects:   6% (2/29)           remote: Counting objects:  10% (3/29)           remote: Counting objects:  13% (4/29)           remote: Counting objects:  17% (5/29)           remote: Counting objects:  20% (6/29)           remote: Counting objects:  24% (7/29)           remote: Counting objects:  27% (8/29)           remote: Counting objects:  31% (9/29)           remote: Counting objects:  34% (10/29)           remote: Counting objects:  37% (11/29)           remote: Counting objects:  41% (12/29)           remote: Counting objects:  44% (13/29)           remote: Counting objects:  48% (14/29)           remote: Counting objects:  51% (15/29)           remote: Counting objects:  55% (16/29)           remote: Counting objects:  58% (17/29)           remote: Counting objects:  62% (18/29)           remote: Counting objects:  65% (19/29)           remote: Counting objects:  68% (20/29)           remote: Counting objects:  72% (21/29)           remote: Counting objects:  75% (22/29)           remote: Counting objects:  79% (23/29)           remote: Counting objects:  82% (24/29)           remote: Counting objects:  86% (25/29)           remote: Counting objects:  89% (26/29)           remote: Counting objects:  93% (27/29)           remote: Counting objects:  96% (28/29)           remote: Counting objects: 100% (29/29)           remote: Counting objects: 100% (29/29), done.        
remote: Compressing objects:   3% (1/26)           remote: Compressing objects:   7% (2/26)           remote: Compressing objects:  11% (3/26)           remote: Compressing objects:  15% (4/26)           remote: Compressing objects:  19% (5/26)           remote: Compressing objects:  23% (6/26)           remote: Compressing objects:  26% (7/26)           remote: Compressing objects:  30% (8/26)           remote: Compressing objects:  34% (9/26)           remote: Compressing objects:  38% (10/26)           remote: Compressing objects:  42% (11/26)           remote: Compressing objects:  46% (12/26)           remote: Compressing objects:  50% (13/26)           remote: Compressing objects:  53% (14/26)           remote: Compressing objects:  57% (15/26)           remote: Compressing objects:  61% (16/26)           remote: Compressing objects:  65% (17/26)           remote: Compressing objects:  69% (18/26)           remote: Compressing objects:  73% (19/26)           remote: Compressing objects:  76% (20/26)           remote: Compressing objects:  80% (21/26)           remote: Compressing objects:  84% (22/26)           remote: Compressing objects:  88% (23/26)           remote: Compressing objects:  92% (24/26)           remote: Compressing objects:  96% (25/26)           remote: Compressing objects: 100% (26/26)           remote: Compressing objects: 100% (26/26), done.        
Receiving objects:   0% (1/170510)   Receiving objects:   0% (194/170510), 68.01 KiB | 102.00 KiB/s   Receiving objects:   0% (277/170510), 116.01 KiB | 54.00 KiB/s   Receiving objects:   0% (472/170510), 164.01 KiB | 59.00 KiB/s   Receiving objects:   0% (692/170510), 284.01 KiB | 70.00 KiB/s   Receiving objects:   0% (893/170510), 380.01 KiB | 73.00 KiB/s   Receiving objects:   0% (1183/170510), 444.01 KiB | 78.00 KiB/s   Receiving objects:   0% (1315/170510), 548.01 KiB | 80.00 KiB/s   Receiving objects:   0% (1471/170510), 580.01 KiB | 84.00 KiB/s   Receiving objects:   1% (1706/170510), 700.01 KiB | 89.00 KiB/s   Receiving objects:   1% (1768/170510), 700.01 KiB | 89.00 KiB/s   Receiving objects:   1% (1908/170510), 796.01 KiB | 85.00 KiB/s   Receiving objects:   1% (2034/170510), 836.01 KiB | 82.00 KiB/s   Receiving objects:   1% (2164/170510), 908.01 KiB | 66.00 KiB/s   Receiving objects:   1% (2268/170510), 932.01 KiB | 66.00 KiB/s   Receiving objects:   1% (2393/170510), 1004.01 KiB | 65.00 KiB/s   Receiving objects:   1% (2662/170510), 1.10 MiB | 64.00 KiB/s   Receiving objects:   1% (2844/170510), 1.14 MiB | 66.00 KiB/s   Receiving objects:   1% (3003/170510), 1.22 MiB | 72.00 KiB/s   Receiving objects:   1% (3096/170510), 1.28 MiB | 70.00 KiB/s   Receiving objects:   1% (3276/170510), 1.31 MiB | 70.00 KiB/s   Receiving objects:   2% (3411/170510), 1.36 MiB | 73.00 KiB/s   Receiving objects:   2% (3592/170510), 1.42 MiB | 75.00 KiB/s   Receiving objects:   2% (3758/170510), 1.50 MiB | 71.00 KiB/s   Receiving objects:   2% (4122/170510), 1.62 MiB | 80.00 KiB/s   Receiving objects:   2% (4605/170510), 1.81 MiB | 111.00 KiB/s   Receiving objects:   2% (4978/170510), 1.96 MiB | 126.00 KiB/s   Receiving objects:   3% (5116/170510), 1.96 MiB | 126.00 KiB/s   Receiving objects:   3% (5195/170510), 2.01 MiB | 124.00 KiB/s   Receiving objects:   3% (5405/170510), 2.09 MiB | 119.00 KiB/s   Receiving objects:   3% (5592/170510), 2.12 MiB | 111.00 KiB/s   Receiving objects:   3% (5877/170510), 2.21 MiB | 98.00 KiB/s   Receiving objects:   3% (6068/170510), 2.32 MiB | 81.00 KiB/s   Receiving objects:   3% (6244/170510), 2.40 MiB | 73.00 KiB/s   Receiving objects:   3% (6414/170510), 2.43 MiB | 71.00 KiB/s   Receiving objects:   3% (6511/170510), 2.46 MiB | 66.00 KiB/s   Receiving objects:   3% (6795/170510), 2.56 MiB | 67.00 KiB/s   Receiving objects:   4% (6821/170510), 2.56 MiB | 67.00 KiB/s   Receiving objects:   4% (7008/170510), 2.61 MiB | 69.00 KiB/s   Receiving objects:   4% (7316/170510), 2.71 MiB | 68.00 KiB/s   Receiving objects:   4% (7546/170510), 2.82 MiB | 72.00 KiB/s   Receiving objects:   4% (7790/170510), 2.84 MiB | 71.00 KiB/s   Receiving objects:   4% (8177/170510), 2.94 MiB | 82.00 KiB/s   Receiving objects:   5% (8526/170510), 3.04 MiB | 83.00 KiB/s   Receiving objects:   5% (8614/170510), 3.04 MiB | 83.00 KiB/s   Receiving objects:   5% (8937/170510), 3.13 MiB | 82.00 KiB/s   Receiving objects:   5% (9154/170510), 3.22 MiB | 81.00 KiB/s   Receiving objects:   5% (9320/170510), 3.29 MiB | 91.00 KiB/s   Receiving objects:   5% (9384/170510), 3.37 MiB | 85.00 KiB/s   Receiving objects:   5% (9465/170510), 3.47 MiB | 85.00 KiB/s   Receiving objects:   5% (9571/170510), 3.61 MiB | 95.00 KiB/s   Receiving objects:   5% (9650/170510), 3.68 MiB | 100.00 KiB/s   Receiving objects:   5% (9759/170510), 3.85 MiB | 109.00 KiB/s   Receiving objects:   5% (9848/170510), 3.92 MiB | 109.00 KiB/s   Receiving objects:   5% (9988/170510), 4.00 MiB | 108.00 KiB/s   Receiving objects:   5% (10094/170510), 4.05 MiB | 98.00 KiB/s   Receiving objects:   5% (10161/170510), 4.11 MiB | 84.00 KiB/s   Receiving objects:   6% (10231/170510), 4.16 MiB | 76.00 KiB/s   Receiving objects:   6% (10268/170510), 4.23 MiB | 75.00 KiB/s   Receiving objects:   6% (10314/170510), 4.30 MiB | 75.00 KiB/s   Receiving objects:   6% (10382/170510), 4.33 MiB | 72.00 KiB/s   Receiving objects:   6% (10458/170510), 4.41 MiB | 73.00 KiB/s   Receiving objects:   6% (10603/170510), 4.52 MiB | 83.00 KiB/s   Receiving objects:   6% (10750/170510), 4.65 MiB | 86.00 KiB/s   Receiving objects:   6% (10869/170510), 4.69 MiB | 86.00 KiB/s   Receiving objects:   6% (10993/170510), 4.79 MiB | 92.00 KiB/s   Receiving objects:   6% (11147/170510), 4.91 MiB | 100.00 KiB/s   Receiving objects:   6% (11171/170510), 4.97 MiB | 90.00 KiB/s   Receiving objects:   6% (11196/170510), 5.00 MiB | 78.00 KiB/s   Receiving objects:   6% (11285/170510), 5.12 MiB | 83.00 KiB/s   Receiving objects:   6% (11418/170510), 5.26 MiB | 94.00 KiB/s   Receiving objects:   6% (11534/170510), 5.42 MiB | 102.00 KiB/s   Receiving objects:   6% (11811/170510), 5.51 MiB | 114.00 KiB/s   Receiving objects:   7% (11936/170510), 5.64 MiB | 135.00 KiB/s   Receiving objects:   7% (12156/170510), 5.76 MiB | 157.00 KiB/s   Receiving objects:   7% (12235/170510), 5.91 MiB | 162.00 KiB/s   Receiving objects:   7% (12417/170510), 6.03 MiB | 157.00 KiB/s   Receiving objects:   7% (12477/170510), 6.07 MiB | 148.00 KiB/s   Receiving objects:   7% (12561/170510), 6.18 MiB | 131.00 KiB/s   Receiving objects:   7% (12663/170510), 6.26 MiB | 95.00 KiB/s   Receiving objects:   7% (12694/170510), 6.31 MiB | 84.00 KiB/s   Receiving objects:   7% (12760/170510), 6.40 MiB | 77.00 KiB/s   Receiving objects:   7% (12823/170510), 6.48 MiB | 74.00 KiB/s   Receiving objects:   7% (12850/170510), 6.50 MiB | 68.00 KiB/s   Receiving objects:   7% (12897/170510), 6.57 MiB | 66.00 KiB/s   Receiving objects:   7% (12943/170510), 6.68 MiB | 72.00 KiB/s   Receiving objects:   7% (12985/170510), 6.72 MiB | 70.00 KiB/s   Receiving objects:   7% (13046/170510), 6.78 MiB | 65.00 KiB/s   Receiving objects:   7% (13101/170510), 6.86 MiB | 68.00 KiB/s   Receiving objects:   7% (13113/170510), 6.93 MiB | 71.00 KiB/s   Receiving objects:   7% (13187/170510), 6.99 MiB | 71.00 KiB/s   Receiving objects:   7% (13234/170510), 7.08 MiB | 73.00 KiB/s   Receiving objects:   7% (13303/170510), 7.14 MiB | 70.00 KiB/s   Receiving objects:   7% (13342/170510), 7.16 MiB | 67.00 KiB/s   Receiving objects:   7% (13416/170510), 7.25 MiB | 69.00 KiB/s   Receiving objects:   7% (13469/170510), 7.33 MiB | 66.00 KiB/s   Receiving objects:   7% (13558/170510), 7.43 MiB | 66.00 KiB/s   Receiving objects:   8% (13641/170510), 7.43 MiB | 66.00 KiB/s   Receiving objects:   8% (13657/170510), 7.47 MiB | 69.00 KiB/s   Receiving objects:   8% (13737/170510), 7.57 MiB | 81.00 KiB/s   Receiving objects:   8% (13787/170510), 7.63 MiB | 82.00 KiB/s   Receiving objects:   8% (13864/170510), 7.73 MiB | 83.00 KiB/s   Receiving objects:   8% (13902/170510), 7.82 MiB | 84.00 KiB/s   Receiving objects:   8% (13944/170510), 7.87 MiB | 77.00 KiB/s   Receiving objects:   8% (14013/170510), 7.91 MiB | 77.00 KiB/s   Receiving objects:   8% (14071/170510), 7.99 MiB | 70.00 KiB/s   Receiving objects:   8% (14180/170510), 8.07 MiB | 67.00 KiB/s   Receiving objects:   8% (14261/170510), 8.21 MiB | 77.00 KiB/s   Receiving objects:   8% (14306/170510), 8.32 MiB | 90.00 KiB/s   Receiving objects:   8% (14307/170510), 8.43 MiB | 98.00 KiB/s   Receiving objects:   8% (14310/170510), 8.50 MiB | 101.00 KiB/s   Receiving objects:   8% (14313/170510), 8.62 MiB | 109.00 KiB/s   Receiving objects:   8% (14314/170510), 8.68 MiB | 104.00 KiB/s   Receiving objects:   8% (14316/170510), 8.82 MiB | 98.00 KiB/s   Receiving objects:   8% (14316/170510), 8.87 MiB | 97.00 KiB/s   Receiving objects:   8% (14316/170510), 8.94 MiB | 85.00 KiB/s   Receiving objects:   8% (14316/170510), 9.05 MiB | 81.00 KiB/s   Receiving objects:   8% (14317/170510), 9.09 MiB | 77.00 KiB/s   Receiving objects:   8% (14318/170510), 9.19 MiB | 82.00 KiB/s   Receiving objects:   8% (14319/170510), 9.30 MiB | 84.00 KiB/s   Receiving objects:   8% (14319/170510), 9.39 MiB | 87.00 KiB/s   Receiving objects:   8% (14320/170510), 9.44 MiB | 85.00 KiB/s   Receiving objects:   8% (14320/170510), 9.52 MiB | 87.00 KiB/s   Receiving objects:   8% (14322/170510), 9.62 MiB | 85.00 KiB/s   Receiving objects:   8% (14323/170510), 9.72 MiB | 84.00 KiB/s   Receiving objects:   8% (14325/170510), 9.79 MiB | 91.00 KiB/s   Receiving objects:   8% (14326/170510), 9.92 MiB | 96.00 KiB/s   Receiving objects:   8% (14327/170510), 10.01 MiB | 97.00 KiB/s   Receiving objects:   8% (14328/170510), 10.11 MiB | 95.00 KiB/s   Receiving objects:   8% (14329/170510), 10.17 MiB | 98.00 KiB/s   Receiving objects:   8% (14332/170510), 10.25 MiB | 104.00 KiB/s   Receiving objects:   8% (14333/170510), 10.44 MiB | 103.00 KiB/s   Receiving objects:   8% (14333/170510), 10.48 MiB | 92.00 KiB/s   Receiving objects:   8% (14335/170510), 10.52 MiB | 82.00 KiB/s   Receiving objects:   8% (14336/170510), 10.57 MiB | 80.00 KiB/s   Receiving objects:   8% (14337/170510), 10.61 MiB | 70.00 KiB/s   Receiving objects:   8% (14338/170510), 10.75 MiB | 60.00 KiB/s   Receiving objects:   8% (14339/170510), 10.80 MiB | 63.00 KiB/s   Receiving objects:   8% (14339/170510), 10.88 MiB | 72.00 KiB/s   Receiving objects:   8% (14341/170510), 10.93 MiB | 77.00 KiB/s   Receiving objects:   8% (14342/170510), 11.06 MiB | 84.00 KiB/s   Receiving objects:   8% (14377/170510), 11.13 MiB | 89.00 KiB/s   Receiving objects:   8% (14390/170510), 11.21 MiB | 87.00 KiB/s   Receiving objects:   8% (14408/170510), 11.29 MiB | 83.00 KiB/s   Receiving objects:   8% (14415/170510), 11.32 MiB | 83.00 KiB/s   Receiving objects:   8% (14451/170510), 11.40 MiB | 77.00 KiB/s   Receiving objects:   8% (14477/170510), 11.43 MiB | 67.00 KiB/s   Receiving objects:   8% (14617/170510), 11.47 MiB | 60.00 KiB/s   Receiving objects:   8% (14795/170510), 11.60 MiB | 68.00 KiB/s   Receiving objects:   8% (14937/170510), 11.71 MiB | 77.00 KiB/s   Receiving objects:   8% (15056/170510), 11.80 MiB | 80.00 KiB/s   Receiving objects:   8% (15279/170510), 11.93 MiB | 96.00 KiB/s   Receiving objects:   9% (15346/170510), 11.96 MiB | 99.00 KiB/s   Receiving objects:   9% (15349/170510), 12.00 MiB | 92.00 KiB/s   Receiving objects:   9% (15416/170510), 12.03 MiB | 85.00 KiB/s   Receiving objects:   9% (15487/170510), 12.13 MiB | 82.00 KiB/s   Receiving objects:   9% (15679/170510), 12.21 MiB | 88.00 KiB/s   Receiving objects:   9% (15805/170510), 12.35 MiB | 91.00 KiB/s   Receiving objects:   9% (15887/170510), 12.42 MiB | 85.00 KiB/s   Receiving objects:   9% (15922/170510), 12.45 MiB | 84.00 KiB/s   Receiving objects:   9% (16012/170510), 12.54 MiB | 88.00 KiB/s   Receiving objects:   9% (16174/170510), 12.68 MiB | 88.00 KiB/s   Receiving objects:   9% (16341/170510), 12.81 MiB | 89.00 KiB/s   Receiving objects:   9% (16439/170510), 12.86 MiB | 95.00 KiB/s   Receiving objects:   9% (16582/170510), 13.01 MiB | 114.00 KiB/s   Receiving objects:   9% (16690/170510), 13.12 MiB | 118.00 KiB/s   Receiving objects:   9% (16887/170510), 13.23 MiB | 111.00 KiB/s   Receiving objects:  10% (17051/170510), 13.27 MiB | 107.00 KiB/s   Receiving objects:  10% (17067/170510), 13.27 MiB | 107.00 KiB/s   Receiving objects:  10% (17194/170510), 13.36 MiB | 100.00 KiB/s   Receiving objects:  10% (17360/170510), 13.46 MiB | 93.00 KiB/s   Receiving objects:  10% (17507/170510), 13.60 MiB | 98.00 KiB/s   Receiving objects:  10% (17681/170510), 13.71 MiB | 99.00 KiB/s   Receiving objects:  10% (17713/170510), 13.75 MiB | 91.00 KiB/s   Receiving objects:  10% (17853/170510), 13.80 MiB | 91.00 KiB/s   Receiving objects:  10% (18024/170510), 13.96 MiB | 100.00 KiB/s   Receiving objects:  10% (18059/170510), 14.01 MiB | 83.00 KiB/s   Receiving objects:  10% (18147/170510), 14.08 MiB | 75.00 KiB/s   Receiving objects:  10% (18364/170510), 14.14 MiB | 79.00 KiB/s   Receiving objects:  10% (18501/170510), 14.23 MiB | 81.00 KiB/s   Receiving objects:  10% (18545/170510), 14.26 MiB | 71.00 KiB/s   Receiving objects:  10% (18742/170510), 14.39 MiB | 75.00 KiB/s   Receiving objects:  11% (18757/170510), 14.39 MiB | 75.00 KiB/s   Receiving objects:  11% (18906/170510), 14.51 MiB | 87.00 KiB/s   Receiving objects:  11% (18963/170510), 14.55 MiB | 85.00 KiB/s   Receiving objects:  11% (19031/170510), 14.66 MiB | 87.00 KiB/s   Receiving objects:  11% (19103/170510), 14.71 MiB | 89.00 KiB/s   Receiving objects:  11% (19177/170510), 14.82 MiB | 93.00 KiB/s   Receiving objects:  11% (19204/170510), 14.89 MiB | 77.00 KiB/s   Receiving objects:  11% (19276/170510), 14.92 MiB | 76.00 KiB/s   Receiving objects:  11% (19403/170510), 15.00 MiB | 76.00 KiB/s   Receiving objects:  11% (19477/170510), 15.11 MiB | 75.00 KiB/s   Receiving objects:  11% (19545/170510), 15.18 MiB | 68.00 KiB/s   Receiving objects:  11% (19853/170510), 15.21 MiB | 69.00 KiB/s   Receiving objects:  11% (20100/170510), 15.34 MiB | 83.00 KiB/s   Receiving objects:  11% (20260/170510), 15.54 MiB | 104.00 KiB/s   Receiving objects:  11% (20446/170510), 15.62 MiB | 104.00 KiB/s   Receiving objects:  12% (20462/170510), 15.62 MiB | 104.00 KiB/s   Receiving objects:  12% (20545/170510), 15.66 MiB | 105.00 KiB/s   Receiving objects:  12% (20637/170510), 15.74 MiB | 106.00 KiB/s   Receiving objects:  12% (20771/170510), 15.84 MiB | 99.00 KiB/s   Receiving objects:  12% (20863/170510), 15.92 MiB | 77.00 KiB/s   Receiving objects:  12% (20960/170510), 15.96 MiB | 75.00 KiB/s   Receiving objects:  12% (21023/170510), 16.05 MiB | 74.00 KiB/s   Receiving objects:  12% (21069/170510), 16.07 MiB | 69.00 KiB/s   Receiving objects:  12% (21120/170510), 16.16 MiB | 69.00 KiB/s   Receiving objects:  12% (21151/170510), 16.21 MiB | 61.00 KiB/s   Receiving objects:  12% (21228/170510), 16.23 MiB | 56.00 KiB/s   Receiving objects:  12% (21312/170510), 16.35 MiB | 60.00 KiB/s   Receiving objects:  12% (21508/170510), 16.50 MiB | 83.00 KiB/s   Receiving objects:  12% (21661/170510), 16.58 MiB | 88.00 KiB/s   Receiving objects:  12% (21786/170510), 16.71 MiB | 99.00 KiB/s   Receiving objects:  12% (21872/170510), 16.82 MiB | 114.00 KiB/s   Receiving objects:  12% (22084/170510), 16.94 MiB | 117.00 KiB/s   Receiving objects:  13% (22167/170510), 16.94 MiB | 117.00 KiB/s   Receiving objects:  13% (22225/170510), 17.01 MiB | 117.00 KiB/s   Receiving objects:  13% (22353/170510), 17.13 MiB | 108.00 KiB/s   Receiving objects:  13% (22511/170510), 17.21 MiB | 98.00 KiB/s   Receiving objects:  13% (22628/170510), 17.28 MiB | 99.00 KiB/s   Receiving objects:  13% (22680/170510), 17.40 MiB | 104.00 KiB/s   Receiving objects:  13% (22856/170510), 17.53 MiB | 102.00 KiB/s   Receiving objects:  13% (22944/170510), 17.64 MiB | 102.00 KiB/s   Receiving objects:  13% (23074/170510), 17.71 MiB | 102.00 KiB/s   Receiving objects:  13% (23165/170510), 17.77 MiB | 85.00 KiB/s   Receiving objects:  13% (23299/170510), 17.82 MiB | 87.00 KiB/s   Receiving objects:  13% (23551/170510), 17.96 MiB | 89.00 KiB/s   Receiving objects:  13% (23691/170510), 18.14 MiB | 103.00 KiB/s   Receiving objects:  13% (23741/170510), 18.24 MiB | 107.00 KiB/s   Receiving objects:  13% (23793/170510), 18.32 MiB | 112.00 KiB/s   Receiving objects:  13% (23857/170510), 18.39 MiB | 111.00 KiB/s   Receiving objects:  14% (23872/170510), 18.39 MiB | 111.00 KiB/s   Receiving objects:  14% (23958/170510), 18.47 MiB | 102.00 KiB/s   Receiving objects:  14% (24102/170510), 18.59 MiB | 89.00 KiB/s   Receiving objects:  14% (24225/170510), 18.64 MiB | 88.00 KiB/s   Receiving objects:  14% (24348/170510), 18.75 MiB | 91.00 KiB/s   Receiving objects:  14% (24576/170510), 18.80 MiB | 84.00 KiB/s   Receiving objects:  14% (24664/170510), 18.91 MiB | 87.00 KiB/s   Receiving objects:  14% (24963/170510), 18.95 MiB | 81.00 KiB/s   Receiving objects:  14% (25091/170510), 18.99 MiB | 65.00 KiB/s   Receiving objects:  14% (25215/170510), 19.04 MiB | 56.00 KiB/s   Receiving objects:  14% (25531/170510), 19.07 MiB | 55.00 KiB/s   Receiving objects:  15% (25577/170510), 19.11 MiB | 58.00 KiB/s   Receiving objects:  15% (25785/170510), 19.18 MiB | 61.00 KiB/s   Receiving objects:  15% (25856/170510), 19.25 MiB | 57.00 KiB/s   Receiving objects:  15% (26232/170510), 19.29 MiB | 61.00 KiB/s   Receiving objects:  15% (26423/170510), 19.43 MiB | 80.00 KiB/s   Receiving objects:  15% (26513/170510), 19.49 MiB | 78.00 KiB/s   Receiving objects:  15% (26881/170510), 19.54 MiB | 81.00 KiB/s   Receiving objects:  16% (27282/170510), 19.66 MiB | 82.00 KiB/s   Receiving objects:  16% (27285/170510), 19.66 MiB | 82.00 KiB/s   Receiving objects:  16% (27487/170510), 19.76 MiB | 91.00 KiB/s   Receiving objects:  16% (27640/170510), 19.86 MiB | 83.00 KiB/s   Receiving objects:  16% (27742/170510), 19.89 MiB | 87.00 KiB/s   Receiving objects:  16% (27862/170510), 19.99 MiB | 89.00 KiB/s   Receiving objects:  16% (28027/170510), 20.11 MiB | 89.00 KiB/s   Receiving objects:  16% (28157/170510), 20.20 MiB | 87.00 KiB/s   Receiving objects:  16% (28394/170510), 20.25 MiB | 86.00 KiB/s   Receiving objects:  16% (28532/170510), 20.35 MiB | 88.00 KiB/s   Receiving objects:  16% (28618/170510), 20.46 MiB | 87.00 KiB/s   Receiving objects:  16% (28713/170510), 20.50 MiB | 82.00 KiB/s   Receiving objects:  16% (28777/170510), 20.57 MiB | 79.00 KiB/s   Receiving objects:  16% (28905/170510), 20.70 MiB | 85.00 KiB/s   Receiving objects:  17% (28987/170510), 20.70 MiB | 85.00 KiB/s   Receiving objects:  17% (29095/170510), 20.77 MiB | 89.00 KiB/s   Receiving objects:  17% (29226/170510), 20.91 MiB | 95.00 KiB/s   Receiving objects:  17% (29316/170510), 21.04 MiB | 113.00 KiB/s   Receiving objects:  17% (29427/170510), 21.13 MiB | 114.00 KiB/s   Receiving objects:  17% (29638/170510), 21.33 MiB | 128.00 KiB/s   Receiving objects:  17% (29862/170510), 21.38 MiB | 122.00 KiB/s   Receiving objects:  17% (30163/170510), 21.48 MiB | 115.00 KiB/s   Receiving objects:  17% (30311/170510), 21.61 MiB | 112.00 KiB/s   Receiving objects:  17% (30549/170510), 21.79 MiB | 125.00 KiB/s   Receiving objects:  18% (30692/170510), 21.79 MiB | 125.00 KiB/s   Receiving objects:  18% (30741/170510), 21.85 MiB | 118.00 KiB/s   Receiving objects:  18% (30780/170510), 21.90 MiB | 99.00 KiB/s   Receiving objects:  18% (30975/170510), 21.96 MiB | 102.00 KiB/s   Receiving objects:  18% (31130/170510), 22.11 MiB | 111.00 KiB/s   Receiving objects:  18% (31369/170510), 22.26 MiB | 110.00 KiB/s   Receiving objects:  18% (31553/170510), 22.36 MiB | 103.00 KiB/s   Receiving objects:  18% (31704/170510), 22.46 MiB | 114.00 KiB/s   Receiving objects:  18% (31842/170510), 22.51 MiB | 112.00 KiB/s   Receiving objects:  18% (32035/170510), 22.62 MiB | 103.00 KiB/s   Receiving objects:  18% (32115/170510), 22.75 MiB | 98.00 KiB/s   Receiving objects:  18% (32315/170510), 22.89 MiB | 107.00 KiB/s   Receiving objects:  19% (32397/170510), 22.89 MiB | 107.00 KiB/s   Receiving objects:  19% (32486/170510), 22.99 MiB | 106.00 KiB/s   Receiving objects:  19% (32614/170510), 23.03 MiB | 103.00 KiB/s   Receiving objects:  19% (32705/170510), 23.14 MiB | 103.00 KiB/s   Receiving objects:  19% (32727/170510), 23.21 MiB | 87.00 KiB/s   Receiving objects:  19% (32840/170510), 23.25 MiB | 80.00 KiB/s   Receiving objects:  19% (32962/170510), 23.33 MiB | 70.00 KiB/s   Receiving objects:  19% (33021/170510), 23.37 MiB | 71.00 KiB/s   Receiving objects:  19% (33139/170510), 23.46 MiB | 68.00 KiB/s   Receiving objects:  19% (33300/170510), 23.56 MiB | 73.00 KiB/s   Receiving objects:  19% (33395/170510), 23.60 MiB | 75.00 KiB/s   Receiving objects:  19% (33518/170510), 23.67 MiB | 73.00 KiB/s   Receiving objects:  19% (33920/170510), 23.79 MiB | 83.00 KiB/s   Receiving objects:  20% (34102/170510), 23.79 MiB | 83.00 KiB/s   Receiving objects:  20% (34558/170510), 23.89 MiB | 85.00 KiB/s   Receiving objects:  20% (35011/170510), 23.93 MiB | 81.00 KiB/s   Receiving objects:  20% (35735/170510), 24.05 MiB | 87.00 KiB/s   Receiving objects:  21% (35808/170510), 24.05 MiB | 87.00 KiB/s   Receiving objects:  21% (36390/170510), 24.18 MiB | 98.00 KiB/s   Receiving objects:  21% (36679/170510), 24.28 MiB | 95.00 KiB/s   Receiving objects:  21% (37116/170510), 24.33 MiB | 93.00 KiB/s   Receiving objects:  21% (37393/170510), 24.43 MiB | 87.00 KiB/s   Receiving objects:  21% (37462/170510), 24.47 MiB | 84.00 KiB/s   Receiving objects:  22% (37513/170510), 24.47 MiB | 84.00 KiB/s   Receiving objects:  22% (37714/170510), 24.55 MiB | 74.00 KiB/s   Receiving objects:  22% (37929/170510), 24.58 MiB | 69.00 KiB/s   Receiving objects:  22% (38046/170510), 24.70 MiB | 69.00 KiB/s   Receiving objects:  22% (38175/170510), 24.79 MiB | 73.00 KiB/s   Receiving objects:  22% (38328/170510), 24.84 MiB | 79.00 KiB/s   Receiving objects:  22% (38446/170510), 24.94 MiB | 87.00 KiB/s   Receiving objects:  22% (38583/170510), 25.04 MiB | 87.00 KiB/s   Receiving objects:  22% (38915/170510), 25.11 MiB | 89.00 KiB/s   Receiving objects:  23% (39218/170510), 25.26 MiB | 104.00 KiB/s   Receiving objects:  23% (39348/170510), 25.26 MiB | 104.00 KiB/s   Receiving objects:  23% (39565/170510), 25.37 MiB | 104.00 KiB/s   Receiving objects:  23% (39807/170510), 25.49 MiB | 105.00 KiB/s   Receiving objects:  23% (40160/170510), 25.52 MiB | 102.00 KiB/s   Receiving objects:  23% (40416/170510), 25.62 MiB | 103.00 KiB/s   Receiving objects:  23% (40617/170510), 25.69 MiB | 86.00 KiB/s   Receiving objects:  23% (40675/170510), 25.78 MiB | 81.00 KiB/s   Receiving objects:  23% (40756/170510), 25.82 MiB | 67.00 KiB/s   Receiving objects:  23% (40879/170510), 25.86 MiB | 68.00 KiB/s   Receiving objects:  24% (40923/170510), 25.86 MiB | 68.00 KiB/s   Receiving objects:  24% (41058/170510), 25.97 MiB | 68.00 KiB/s   Receiving objects:  24% (41140/170510), 26.04 MiB | 72.00 KiB/s   Receiving objects:  24% (41248/170510), 26.13 MiB | 74.00 KiB/s   Receiving objects:  24% (41447/170510), 26.25 MiB | 81.00 KiB/s   Receiving objects:  24% (41726/170510), 26.41 MiB | 104.00 KiB/s   Receiving objects:  24% (41861/170510), 26.50 MiB | 111.00 KiB/s   Receiving objects:  24% (42007/170510), 26.60 MiB | 111.00 KiB/s   Receiving objects:  24% (42135/170510), 26.68 MiB | 109.00 KiB/s   Receiving objects:  24% (42265/170510), 26.72 MiB | 106.00 KiB/s   Receiving objects:  24% (42395/170510), 26.85 MiB | 102.00 KiB/s   Receiving objects:  24% (42449/170510), 26.93 MiB | 81.00 KiB/s   Receiving objects:  24% (42579/170510), 26.98 MiB | 81.00 KiB/s   Receiving objects:  25% (42628/170510), 27.06 MiB | 83.00 KiB/s   Receiving objects:  25% (42641/170510), 27.07 MiB | 75.00 KiB/s   Receiving objects:  25% (42716/170510), 27.11 MiB | 74.00 KiB/s   Receiving objects:  25% (42780/170510), 27.17 MiB | 61.00 KiB/s   Receiving objects:  25% (42837/170510), 27.20 MiB | 59.00 KiB/s   Receiving objects:  25% (43005/170510), 27.27 MiB | 57.00 KiB/s   Receiving objects:  25% (43078/170510), 27.33 MiB | 52.00 KiB/s   Receiving objects:  25% (43210/170510), 27.39 MiB | 54.00 KiB/s   Receiving objects:  25% (43328/170510), 27.43 MiB | 56.00 KiB/s   Receiving objects:  25% (43529/170510), 27.59 MiB | 74.00 KiB/s   Receiving objects:  25% (43657/170510), 27.71 MiB | 83.00 KiB/s   Receiving objects:  25% (43731/170510), 27.75 MiB | 85.00 KiB/s   Receiving objects:  25% (43840/170510), 27.83 MiB | 91.00 KiB/s   Receiving objects:  25% (43938/170510), 27.93 MiB | 93.00 KiB/s   Receiving objects:  25% (44030/170510), 27.96 MiB | 84.00 KiB/s   Receiving objects:  25% (44054/170510), 28.04 MiB | 66.00 KiB/s   Receiving objects:  25% (44231/170510), 28.08 MiB | 67.00 KiB/s   Receiving objects:  26% (44333/170510), 28.16 MiB | 76.00 KiB/s   Receiving objects:  26% (44488/170510), 28.24 MiB | 83.00 KiB/s   Receiving objects:  26% (44702/170510), 28.36 MiB | 88.00 KiB/s   Receiving objects:  26% (44799/170510), 28.41 MiB | 91.00 KiB/s   Receiving objects:  26% (44951/170510), 28.49 MiB | 96.00 KiB/s   Receiving objects:  26% (44994/170510), 28.56 MiB | 90.00 KiB/s   Receiving objects:  26% (45062/170510), 28.59 MiB | 81.00 KiB/s   Receiving objects:  26% (45225/170510), 28.71 MiB | 76.00 KiB/s   Receiving objects:  26% (45322/170510), 28.80 MiB | 73.00 KiB/s   Receiving objects:  26% (45493/170510), 28.85 MiB | 73.00 KiB/s   Receiving objects:  26% (45626/170510), 28.91 MiB | 70.00 KiB/s   Receiving objects:  26% (45736/170510), 28.98 MiB | 75.00 KiB/s   Receiving objects:  26% (45905/170510), 29.08 MiB | 73.00 KiB/s   Receiving objects:  27% (46038/170510), 29.14 MiB | 74.00 KiB/s   Receiving objects:  27% (46068/170510), 29.14 MiB | 74.00 KiB/s   Receiving objects:  27% (46272/170510), 29.24 MiB | 74.00 KiB/s   Receiving objects:  27% (46408/170510), 29.27 MiB | 73.00 KiB/s   Receiving objects:  27% (46714/170510), 29.41 MiB | 84.00 KiB/s   Receiving objects:  27% (47029/170510), 29.46 MiB | 83.00 KiB/s   Receiving objects:  27% (47221/170510), 29.53 MiB | 75.00 KiB/s   Receiving objects:  27% (47350/170510), 29.54 MiB | 69.00 KiB/s   Receiving objects:  27% (47609/170510), 29.60 MiB | 63.00 KiB/s   Receiving objects:  28% (47743/170510), 29.60 MiB | 63.00 KiB/s   Receiving objects:  28% (48046/170510), 29.69 MiB | 61.00 KiB/s   Receiving objects:  28% (48329/170510), 29.73 MiB | 60.00 KiB/s   Receiving objects:  28% (48473/170510), 29.79 MiB | 53.00 KiB/s   Receiving objects:  28% (48577/170510), 29.81 MiB | 50.00 KiB/s   Receiving objects:  28% (48909/170510), 29.90 MiB | 61.00 KiB/s   Receiving objects:  28% (49204/170510), 30.03 MiB | 70.00 KiB/s   Receiving objects:  28% (49356/170510), 30.06 MiB | 68.00 KiB/s   Receiving objects:  29% (49448/170510), 30.10 MiB | 67.00 KiB/s   Receiving objects:  29% (49705/170510), 30.14 MiB | 73.00 KiB/s   Receiving objects:  29% (50014/170510), 30.26 MiB | 89.00 KiB/s   Receiving objects:  29% (50225/170510), 30.35 MiB | 87.00 KiB/s   Receiving objects:  29% (50383/170510), 30.40 MiB | 86.00 KiB/s   Receiving objects:  29% (50639/170510), 30.54 MiB | 94.00 KiB/s   Receiving objects:  29% (50818/170510), 30.71 MiB | 115.00 KiB/s   Receiving objects:  29% (50876/170510), 30.79 MiB | 103.00 KiB/s   Receiving objects:  29% (50975/170510), 30.84 MiB | 106.00 KiB/s   Receiving objects:  29% (51075/170510), 30.95 MiB | 108.00 KiB/s   Receiving objects:  30% (51153/170510), 31.01 MiB | 108.00 KiB/s   Receiving objects:  30% (51279/170510), 31.09 MiB | 110.00 KiB/s   Receiving objects:  30% (51444/170510), 31.19 MiB | 91.00 KiB/s   Receiving objects:  30% (51541/170510), 31.24 MiB | 97.00 KiB/s   Receiving objects:  30% (51759/170510), 31.35 MiB | 100.00 KiB/s   Receiving objects:  30% (51850/170510), 31.42 MiB | 92.00 KiB/s   Receiving objects:  30% (51947/170510), 31.46 MiB | 89.00 KiB/s   Receiving objects:  30% (52145/170510), 31.58 MiB | 87.00 KiB/s   Receiving objects:  30% (52401/170510), 31.69 MiB | 93.00 KiB/s   Receiving objects:  30% (52469/170510), 31.76 MiB | 82.00 KiB/s   Receiving objects:  30% (52519/170510), 31.82 MiB | 79.00 KiB/s   Receiving objects:  30% (52666/170510), 31.88 MiB | 82.00 KiB/s   Receiving objects:  30% (52790/170510), 31.95 MiB | 71.00 KiB/s   Receiving objects:  31% (52859/170510), 32.00 MiB | 70.00 KiB/s   Receiving objects:  31% (52964/170510), 32.00 MiB | 70.00 KiB/s   Receiving objects:  31% (53026/170510), 32.09 MiB | 69.00 KiB/s   Receiving objects:  31% (53303/170510), 32.18 MiB | 76.00 KiB/s   Receiving objects:  31% (53590/170510), 32.29 MiB | 80.00 KiB/s   Receiving objects:  31% (53852/170510), 32.39 MiB | 88.00 KiB/s   Receiving objects:  31% (54090/170510), 32.48 MiB | 83.00 KiB/s   Receiving objects:  31% (54277/170510), 32.54 MiB | 88.00 KiB/s   Receiving objects:  31% (54466/170510), 32.64 MiB | 91.00 KiB/s   Receiving objects:  31% (54559/170510), 32.71 MiB | 80.00 KiB/s   Receiving objects:  32% (54564/170510), 32.71 MiB | 80.00 KiB/s   Receiving objects:  32% (54666/170510), 32.74 MiB | 75.00 KiB/s   Receiving objects:  32% (54782/170510), 32.85 MiB | 81.00 KiB/s   Receiving objects:  32% (54881/170510), 32.95 MiB | 81.00 KiB/s   Receiving objects:  32% (55052/170510), 33.01 MiB | 84.00 KiB/s   Receiving objects:  32% (55199/170510), 33.14 MiB | 91.00 KiB/s   Receiving objects:  32% (55234/170510), 33.21 MiB | 89.00 KiB/s   Receiving objects:  32% (55283/170510), 33.23 MiB | 83.00 KiB/s   Receiving objects:  32% (55448/170510), 33.30 MiB | 73.00 KiB/s   Receiving objects:  32% (55563/170510), 33.34 MiB | 70.00 KiB/s   Receiving objects:  32% (55652/170510), 33.43 MiB | 64.00 KiB/s   Receiving objects:  32% (55852/170510), 33.54 MiB | 66.00 KiB/s   Receiving objects:  32% (56088/170510), 33.60 MiB | 72.00 KiB/s   Receiving objects:  32% (56179/170510), 33.68 MiB | 81.00 KiB/s   Receiving objects:  33% (56269/170510), 33.75 MiB | 79.00 KiB/s   Receiving objects:  33% (56299/170510), 33.75 MiB | 79.00 KiB/s   Receiving objects:  33% (56470/170510), 33.81 MiB | 83.00 KiB/s   Receiving objects:  33% (56628/170510), 33.90 MiB | 77.00 KiB/s   Receiving objects:  33% (56691/170510), 33.99 MiB | 72.00 KiB/s   Receiving objects:  33% (56750/170510), 34.02 MiB | 68.00 KiB/s   Receiving objects:  33% (56907/170510), 34.11 MiB | 73.00 KiB/s   Receiving objects:  33% (57044/170510), 34.21 MiB | 76.00 KiB/s   Receiving objects:  33% (57234/170510), 34.31 MiB | 78.00 KiB/s   Receiving objects:  33% (57339/170510), 34.32 MiB | 72.00 KiB/s   Receiving objects:  33% (57562/170510), 34.41 MiB | 79.00 KiB/s   Receiving objects:  33% (57782/170510), 34.54 MiB | 86.00 KiB/s   Receiving objects:  33% (57896/170510), 34.58 MiB | 82.00 KiB/s   Receiving objects:  34% (57974/170510), 34.66 MiB | 77.00 KiB/s   Receiving objects:  34% (57975/170510), 34.66 MiB | 77.00 KiB/s   Receiving objects:  34% (58063/170510), 34.75 MiB | 81.00 KiB/s   Receiving objects:  34% (58235/170510), 34.81 MiB | 85.00 KiB/s   Receiving objects:  34% (58338/170510), 34.87 MiB | 74.00 KiB/s   Receiving objects:  34% (58439/170510), 34.97 MiB | 73.00 KiB/s   Receiving objects:  34% (58819/170510), 35.04 MiB | 80.00 KiB/s   Receiving objects:  34% (59102/170510), 35.17 MiB | 88.00 KiB/s   Receiving objects:  34% (59334/170510), 35.22 MiB | 86.00 KiB/s   Receiving objects:  35% (59679/170510), 35.32 MiB | 89.00 KiB/s   Receiving objects:  35% (59692/170510), 35.32 MiB | 89.00 KiB/s   Receiving objects:  35% (60071/170510), 35.46 MiB | 101.00 KiB/s   Receiving objects:  35% (60198/170510), 35.60 MiB | 106.00 KiB/s   Receiving objects:  35% (60332/170510), 35.64 MiB | 107.00 KiB/s   Receiving objects:  35% (60491/170510), 35.78 MiB | 111.00 KiB/s   Receiving objects:  35% (60633/170510), 35.89 MiB | 112.00 KiB/s   Receiving objects:  35% (60648/170510), 35.92 MiB | 104.00 KiB/s   Receiving objects:  35% (60721/170510), 35.99 MiB | 80.00 KiB/s   Receiving objects:  35% (60835/170510), 36.03 MiB | 79.00 KiB/s   Receiving objects:  35% (60974/170510), 36.12 MiB | 77.00 KiB/s   Receiving objects:  35% (61056/170510), 36.19 MiB | 63.00 KiB/s   Receiving objects:  35% (61227/170510), 36.23 MiB | 61.00 KiB/s   Receiving objects:  35% (61261/170510), 36.33 MiB | 66.00 KiB/s   Receiving objects:  35% (61350/170510), 36.36 MiB | 67.00 KiB/s   Receiving objects:  36% (61384/170510), 36.36 MiB | 67.00 KiB/s   Receiving objects:  36% (61501/170510), 36.44 MiB | 68.00 KiB/s   Receiving objects:  36% (61743/170510), 36.57 MiB | 76.00 KiB/s   Receiving objects:  36% (61931/170510), 36.67 MiB | 82.00 KiB/s   Receiving objects:  36% (62157/170510), 36.75 MiB | 85.00 KiB/s   Receiving objects:  36% (62254/170510), 36.79 MiB | 85.00 KiB/s   Receiving objects:  36% (62409/170510), 36.89 MiB | 89.00 KiB/s   Receiving objects:  36% (62584/170510), 37.00 MiB | 84.00 KiB/s   Receiving objects:  36% (63024/170510), 37.07 MiB | 90.00 KiB/s   Receiving objects:  37% (63089/170510), 37.17 MiB | 99.00 KiB/s   Receiving objects:  37% (63195/170510), 37.24 MiB | 105.00 KiB/s   Receiving objects:  37% (63278/170510), 37.34 MiB | 106.00 KiB/s   Receiving objects:  37% (63385/170510), 37.39 MiB | 109.00 KiB/s   Receiving objects:  37% (63430/170510), 37.48 MiB | 103.00 KiB/s   Receiving objects:  37% (63461/170510), 37.50 MiB | 92.00 KiB/s   Receiving objects:  37% (63512/170510), 37.57 MiB | 71.00 KiB/s   Receiving objects:  37% (63617/170510), 37.62 MiB | 67.00 KiB/s   Receiving objects:  37% (63695/170510), 37.71 MiB | 66.00 KiB/s   Receiving objects:  37% (63820/170510), 37.82 MiB | 66.00 KiB/s   Receiving objects:  37% (63964/170510), 37.93 MiB | 82.00 KiB/s   Receiving objects:  37% (64122/170510), 38.03 MiB | 90.00 KiB/s   Receiving objects:  37% (64248/170510), 38.09 MiB | 93.00 KiB/s   Receiving objects:  37% (64422/170510), 38.21 MiB | 103.00 KiB/s   Receiving objects:  37% (64501/170510), 38.31 MiB | 100.00 KiB/s   Receiving objects:  37% (64623/170510), 38.43 MiB | 97.00 KiB/s   Receiving objects:  37% (64721/170510), 38.46 MiB | 86.00 KiB/s   Receiving objects:  38% (64794/170510), 38.50 MiB | 85.00 KiB/s   Receiving objects:  38% (64853/170510), 38.50 MiB | 85.00 KiB/s   Receiving objects:  38% (64944/170510), 38.57 MiB | 74.00 KiB/s   Receiving objects:  38% (65079/170510), 38.63 MiB | 64.00 KiB/s   Receiving objects:  38% (65126/170510), 38.65 MiB | 60.00 KiB/s   Receiving objects:  38% (65388/170510), 38.79 MiB | 64.00 KiB/s   Receiving objects:  38% (65546/170510), 38.93 MiB | 86.00 KiB/s   Receiving objects:  38% (65667/170510), 39.04 MiB | 92.00 KiB/s   Receiving objects:  38% (65744/170510), 39.07 MiB | 95.00 KiB/s   Receiving objects:  38% (65857/170510), 39.16 MiB | 99.00 KiB/s   Receiving objects:  38% (66067/170510), 39.26 MiB | 94.00 KiB/s   Receiving objects:  38% (66148/170510), 39.29 MiB | 81.00 KiB/s   Receiving objects:  38% (66306/170510), 39.36 MiB | 68.00 KiB/s   Receiving objects:  38% (66479/170510), 39.41 MiB | 69.00 KiB/s   Receiving objects:  39% (66499/170510), 39.48 MiB | 77.00 KiB/s   Receiving objects:  39% (66625/170510), 39.53 MiB | 79.00 KiB/s   Receiving objects:  39% (66728/170510), 39.63 MiB | 81.00 KiB/s   Receiving objects:  39% (66890/170510), 39.71 MiB | 86.00 KiB/s   Receiving objects:  39% (67189/170510), 39.79 MiB | 90.00 KiB/s   Receiving objects:  39% (67284/170510), 39.89 MiB | 84.00 KiB/s   Receiving objects:  39% (67459/170510), 39.95 MiB | 88.00 KiB/s   Receiving objects:  39% (67542/170510), 40.08 MiB | 92.00 KiB/s   Receiving objects:  39% (67693/170510), 40.21 MiB | 102.00 KiB/s   Receiving objects:  39% (67858/170510), 40.32 MiB | 107.00 KiB/s   Receiving objects:  40% (68204/170510), 40.36 MiB | 105.00 KiB/s   Receiving objects:  40% (68278/170510), 40.41 MiB | 104.00 KiB/s   Receiving objects:  40% (68486/170510), 40.43 MiB | 97.00 KiB/s   Receiving objects:  40% (68683/170510), 40.50 MiB | 82.00 KiB/s   Receiving objects:  40% (68815/170510), 40.62 MiB | 79.00 KiB/s   Receiving objects:  40% (68946/170510), 40.68 MiB | 82.00 KiB/s   Receiving objects:  40% (69449/170510), 40.79 MiB | 83.00 KiB/s   Receiving objects:  40% (69624/170510), 40.86 MiB | 83.00 KiB/s   Receiving objects:  40% (69830/170510), 40.94 MiB | 88.00 KiB/s   Receiving objects:  41% (69910/170510), 40.96 MiB | 83.00 KiB/s   Receiving objects:  41% (69939/170510), 40.96 MiB | 83.00 KiB/s   Receiving objects:  41% (70023/170510), 41.04 MiB | 67.00 KiB/s   Receiving objects:  41% (70327/170510), 41.15 MiB | 69.00 KiB/s   Receiving objects:  41% (70685/170510), 41.26 MiB | 83.00 KiB/s   Receiving objects:  41% (70842/170510), 41.41 MiB | 98.00 KiB/s   Receiving objects:  41% (70986/170510), 41.54 MiB | 111.00 KiB/s   Receiving objects:  41% (71181/170510), 41.66 MiB | 126.00 KiB/s   Receiving objects:  41% (71287/170510), 41.69 MiB | 125.00 KiB/s   Receiving objects:  41% (71351/170510), 41.76 MiB | 100.00 KiB/s   Receiving objects:  41% (71388/170510), 41.82 MiB | 82.00 KiB/s   Receiving objects:  41% (71488/170510), 41.91 MiB | 73.00 KiB/s   Receiving objects:  42% (71615/170510), 41.96 MiB | 71.00 KiB/s   Receiving objects:  42% (71632/170510), 41.96 MiB | 71.00 KiB/s   Receiving objects:  42% (71702/170510), 42.04 MiB | 68.00 KiB/s   Receiving objects:  42% (71733/170510), 42.11 MiB | 66.00 KiB/s   Receiving objects:  42% (71866/170510), 42.23 MiB | 79.00 KiB/s   Receiving objects:  42% (71955/170510), 42.26 MiB | 78.00 KiB/s   Receiving objects:  42% (72044/170510), 42.36 MiB | 77.00 KiB/s   Receiving objects:  42% (72185/170510), 42.42 MiB | 78.00 KiB/s   Receiving objects:  42% (72291/170510), 42.57 MiB | 92.00 KiB/s   Receiving objects:  42% (72349/170510), 42.60 MiB | 88.00 KiB/s   Receiving objects:  42% (72448/170510), 42.67 MiB | 79.00 KiB/s   Receiving objects:  42% (72502/170510), 42.75 MiB | 78.00 KiB/s   Receiving objects:  42% (72568/170510), 42.82 MiB | 80.00 KiB/s   Receiving objects:  42% (72661/170510), 42.93 MiB | 81.00 KiB/s   Receiving objects:  42% (72759/170510), 43.02 MiB | 81.00 KiB/s   Receiving objects:  42% (72803/170510), 43.10 MiB | 80.00 KiB/s   Receiving objects:  42% (72860/170510), 43.12 MiB | 78.00 KiB/s   Receiving objects:  42% (72902/170510), 43.15 MiB | 72.00 KiB/s   Receiving objects:  42% (72951/170510), 43.22 MiB | 66.00 KiB/s   Receiving objects:  42% (73023/170510), 43.25 MiB | 58.00 KiB/s   Receiving objects:  42% (73149/170510), 43.35 MiB | 58.00 KiB/s   Receiving objects:  42% (73262/170510), 43.43 MiB | 58.00 KiB/s   Receiving objects:  43% (73320/170510), 43.48 MiB | 66.00 KiB/s   Receiving objects:  43% (73368/170510), 43.53 MiB | 69.00 KiB/s   Receiving objects:  43% (73482/170510), 43.57 MiB | 72.00 KiB/s   Receiving objects:  43% (73619/170510), 43.70 MiB | 85.00 KiB/s   Receiving objects:  43% (73745/170510), 43.80 MiB | 86.00 KiB/s   Receiving objects:  43% (73932/170510), 43.87 MiB | 92.00 KiB/s   Receiving objects:  43% (74038/170510), 43.98 MiB | 96.00 KiB/s   Receiving objects:  43% (74085/170510), 44.04 MiB | 87.00 KiB/s   Receiving objects:  43% (74152/170510), 44.06 MiB | 78.00 KiB/s   Receiving objects:  43% (74321/170510), 44.14 MiB | 72.00 KiB/s   Receiving objects:  43% (74416/170510), 44.21 MiB | 65.00 KiB/s   Receiving objects:  43% (74547/170510), 44.25 MiB | 60.00 KiB/s   Receiving objects:  43% (74713/170510), 44.33 MiB | 64.00 KiB/s   Receiving objects:  43% (75023/170510), 44.45 MiB | 79.00 KiB/s   Receiving objects:  44% (75025/170510), 44.45 MiB | 79.00 KiB/s   Receiving objects:  44% (76066/170510), 44.61 MiB | 97.00 KiB/s   Receiving objects:  45% (76730/170510), 44.68 MiB | 102.00 KiB/s   Receiving objects:  45% (76767/170510), 44.76 MiB | 113.00 KiB/s   Receiving objects:  45% (76949/170510), 44.84 MiB | 122.00 KiB/s   Receiving objects:  45% (77061/170510), 44.93 MiB | 119.00 KiB/s   Receiving objects:  45% (77227/170510), 45.01 MiB | 114.00 KiB/s   Receiving objects:  45% (77985/170510), 45.11 MiB | 101.00 KiB/s   Receiving objects:  45% (78143/170510), 45.22 MiB | 88.00 KiB/s   Receiving objects:  46% (78435/170510), 45.26 MiB | 81.00 KiB/s   Receiving objects:  46% (78464/170510), 45.26 MiB | 81.00 KiB/s   Receiving objects:  46% (78745/170510), 45.35 MiB | 82.00 KiB/s   Receiving objects:  46% (78918/170510), 45.39 MiB | 79.00 KiB/s   Receiving objects:  46% (79113/170510), 45.52 MiB | 91.00 KiB/s   Receiving objects:  46% (79535/170510), 45.62 MiB | 84.00 KiB/s   Receiving objects:  46% (79937/170510), 45.74 MiB | 96.00 KiB/s   Receiving objects:  46% (80124/170510), 45.84 MiB | 98.00 KiB/s   Receiving objects:  47% (80140/170510), 45.84 MiB | 98.00 KiB/s   Receiving objects:  47% (80660/170510), 45.91 MiB | 104.00 KiB/s   Receiving objects:  47% (81090/170510), 46.06 MiB | 107.00 KiB/s   Receiving objects:  47% (81814/170510), 46.18 MiB | 110.00 KiB/s   Receiving objects:  48% (81845/170510), 46.18 MiB | 110.00 KiB/s   Receiving objects:  48% (82475/170510), 46.24 MiB | 111.00 KiB/s   Receiving objects:  48% (82793/170510), 46.30 MiB | 101.00 KiB/s   Receiving objects:  48% (83053/170510), 46.35 MiB | 94.00 KiB/s   Receiving objects:  48% (83280/170510), 46.47 MiB | 91.00 KiB/s   Receiving objects:  48% (83473/170510), 46.60 MiB | 88.00 KiB/s   Receiving objects:  49% (83550/170510), 46.60 MiB | 88.00 KiB/s   Receiving objects:  49% (83750/170510), 46.67 MiB | 91.00 KiB/s   Receiving objects:  49% (83943/170510), 46.85 MiB | 109.00 KiB/s   Receiving objects:  49% (84641/170510), 46.98 MiB | 127.00 KiB/s   Receiving objects:  49% (84730/170510), 47.07 MiB | 120.00 KiB/s   Receiving objects:  49% (84808/170510), 47.15 MiB | 112.00 KiB/s   Receiving objects:  50% (85255/170510), 47.21 MiB | 109.00 KiB/s   Receiving objects:  50% (85358/170510), 47.26 MiB | 97.00 KiB/s   Receiving objects:  50% (85575/170510), 47.31 MiB | 89.00 KiB/s   Receiving objects:  50% (86531/170510), 47.44 MiB | 88.00 KiB/s   Receiving objects:  50% (86881/170510), 47.48 MiB | 86.00 KiB/s   Receiving objects:  51% (86961/170510), 47.50 MiB | 80.00 KiB/s   Receiving objects:  51% (87111/170510), 47.53 MiB | 77.00 KiB/s   Receiving objects:  51% (87289/170510), 47.56 MiB | 75.00 KiB/s   Receiving objects:  51% (87723/170510), 47.68 MiB | 78.00 KiB/s   Receiving objects:  51% (88121/170510), 47.77 MiB | 75.00 KiB/s   Receiving objects:  52% (88666/170510), 47.82 MiB | 72.00 KiB/s   Receiving objects:  52% (88793/170510), 47.86 MiB | 72.00 KiB/s   Receiving objects:  52% (89610/170510), 47.90 MiB | 78.00 KiB/s   Receiving objects:  53% (90371/170510), 48.00 MiB | 89.00 KiB/s   Receiving objects:  53% (90479/170510), 48.00 MiB | 89.00 KiB/s   Receiving objects:  53% (90758/170510), 48.14 MiB | 94.00 KiB/s   Receiving objects:  53% (90869/170510), 48.26 MiB | 99.00 KiB/s   Receiving objects:  53% (91025/170510), 48.37 MiB | 103.00 KiB/s   Receiving objects:  53% (91122/170510), 48.45 MiB | 100.00 KiB/s   Receiving objects:  53% (91122/170510), 48.56 MiB | 93.00 KiB/s   Receiving objects:  53% (91122/170510), 48.58 MiB | 84.00 KiB/s   Receiving objects:  53% (91122/170510), 48.65 MiB | 74.00 KiB/s   Receiving objects:  53% (91122/170510), 48.75 MiB | 71.00 KiB/s   Receiving objects:  53% (91122/170510), 48.84 MiB | 75.00 KiB/s   Receiving objects:  53% (91122/170510), 48.90 MiB | 75.00 KiB/s   Receiving objects:  53% (91122/170510), 48.96 MiB | 71.00 KiB/s   Receiving objects:  53% (91122/170510), 49.00 MiB | 76.00 KiB/s   Receiving objects:  53% (91122/170510), 49.07 MiB | 68.00 KiB/s   Receiving objects:  53% (91122/170510), 49.11 MiB | 65.00 KiB/s   Receiving objects:  53% (91122/170510), 49.18 MiB | 58.00 KiB/s   Receiving objects:  53% (91122/170510), 49.21 MiB | 54.00 KiB/s   Receiving objects:  53% (91122/170510), 49.29 MiB | 60.00 KiB/s   Receiving objects:  53% (91122/170510), 49.40 MiB | 67.00 KiB/s   Receiving objects:  53% (91122/170510), 49.48 MiB | 70.00 KiB/s   Receiving objects:  53% (91122/170510), 49.53 MiB | 75.00 KiB/s   error: index-pack died of signal 15
fatal: index-pack failed

	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl.launchCommandIn(CliGitAPIImpl.java:2042)
	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl.launchCommandWithCredentials(CliGitAPIImpl.java:1761)
	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl.access$400(CliGitAPIImpl.java:72)
	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl$1.execute(CliGitAPIImpl.java:442)
	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl$2.execute(CliGitAPIImpl.java:655)
	at org.jenkinsci.plugins.gitclient.RemoteGitImpl$CommandInvocationHandler$1.call(RemoteGitImpl.java:153)
	at org.jenkinsci.plugins.gitclient.RemoteGitImpl$CommandInvocationHandler$1.call(RemoteGitImpl.java:146)
	at hudson.remoting.UserRequest.perform(UserRequest.java:212)
	at hudson.remoting.UserRequest.perform(UserRequest.java:54)
	at hudson.remoting.Request$2.run(Request.java:369)
	at hudson.remoting.InterceptingExecutorService$1.call(InterceptingExecutorService.java:72)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617)
	at java.lang.Thread.run(Thread.java:748)
	Suppressed: hudson.remoting.Channel$CallSiteStackTrace: Remote call to H32
		at hudson.remoting.Channel.attachCallSiteStackTrace(Channel.java:1741)
		at hudson.remoting.UserRequest$ExceptionResponse.retrieve(UserRequest.java:357)
		at hudson.remoting.Channel.call(Channel.java:955)
		at org.jenkinsci.plugins.gitclient.RemoteGitImpl$CommandInvocationHandler.execute(RemoteGitImpl.java:146)
		at sun.reflect.GeneratedMethodAccessor927.invoke(Unknown Source)
		at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
		at java.lang.reflect.Method.invoke(Method.java:498)
		at org.jenkinsci.plugins.gitclient.RemoteGitImpl$CommandInvocationHandler.invoke(RemoteGitImpl.java:132)
		at com.sun.proxy.$Proxy134.execute(Unknown Source)
		at hudson.plugins.git.GitSCM.retrieveChanges(GitSCM.java:1152)
		at hudson.plugins.git.GitSCM.checkout(GitSCM.java:1192)
		at hudson.scm.SCM.checkout(SCM.java:504)
		at hudson.model.AbstractProject.checkout(AbstractProject.java:1208)
		at hudson.model.AbstractBuild$AbstractBuildExecution.defaultCheckout(AbstractBuild.java:574)
		at jenkins.scm.SCMCheckoutStrategy.checkout(SCMCheckoutStrategy.java:86)
		at hudson.model.AbstractBuild$AbstractBuildExecution.run(AbstractBuild.java:499)
		at hudson.model.Run.execute(Run.java:1810)
		at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
		at hudson.model.ResourceController.execute(ResourceController.java:97)
		at hudson.model.Executor.run(Executor.java:429)
ERROR: Error cloning remote repo 'origin'
Retrying after 10 seconds
No credentials specified
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 9fa331b811d893a0d580e9136c1c7e1fa9774542 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 9fa331b811d893a0d580e9136c1c7e1fa9774542
Commit message: "KAFKA-8225 & KIP-345 part-2: fencing static member instances with conflicting group.instance.id (#6650)"
 > git rev-list --no-walk e2847e8603fe19a87ff03584fb38954e4bd3a59e # timeout=10
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: No tool found matching GRADLE_4_10_2_HOME
[kafka-trunk-jdk11] $ /bin/bash -xe /tmp/jenkins993920956239506716.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk11/ws/.gradle>
+ /bin/gradle
/tmp/jenkins993920956239506716.sh: line 4: /bin/gradle: No such file or directory
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
ERROR: No tool found matching GRADLE_4_10_2_HOME
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #543

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

Changes:

[jason] KAFKA-8365; Consumer and protocol support for follower fetching (#6731)

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H28 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk11/ws/>
[WS-CLEANUP] Deleting project workspace...
[WS-CLEANUP] Deferred wipeout is used...
[WS-CLEANUP] Done
No credentials specified
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-trunk-jdk11/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision e2847e8603fe19a87ff03584fb38954e4bd3a59e (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f e2847e8603fe19a87ff03584fb38954e4bd3a59e
Commit message: "KAFKA-8365; Consumer and protocol support for follower fetching (#6731)"
 > git rev-list --no-walk d6057a9fe44b5e9521dd679b0dc1e6ccfec866c2 # timeout=10
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: No tool found matching GRADLE_4_10_2_HOME
[kafka-trunk-jdk11] $ /bin/bash -xe /tmp/jenkins8987851443174875671.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk11/ws/.gradle>
+ /bin/gradle
/tmp/jenkins8987851443174875671.sh: line 4: /bin/gradle: No such file or directory
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
ERROR: No tool found matching GRADLE_4_10_2_HOME
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #542

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

Changes:

[bbejeck] KAFKA-6455: Improve DSL operator timestamp semantics (#6725)

[cshapi] MINOR: Remove spammy log message during topic deletion

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H24 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk11/ws/>
[WS-CLEANUP] Deleting project workspace...
[WS-CLEANUP] Deferred wipeout is used...
[WS-CLEANUP] Done
No credentials specified
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-trunk-jdk11/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision d6057a9fe44b5e9521dd679b0dc1e6ccfec866c2 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f d6057a9fe44b5e9521dd679b0dc1e6ccfec866c2
Commit message: "MINOR: Remove spammy log message during topic deletion"
 > git rev-list --no-walk e018bfe2b050b55b479bbabb9fc26ebcc211b177 # timeout=10
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: No tool found matching GRADLE_4_10_2_HOME
[kafka-trunk-jdk11] $ /bin/bash -xe /tmp/jenkins9108979542650919934.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk11/ws/.gradle>
+ /bin/gradle
/tmp/jenkins9108979542650919934.sh: line 4: /bin/gradle: No such file or directory
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
ERROR: No tool found matching GRADLE_4_10_2_HOME
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #541

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

Changes:

[jason] KAFKA-8346; Improve replica fetcher behavior for handling partition

[bbejeck] KAFKA-3522: TopologyTestDriver should only return custom stores via

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H30 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk11/ws/>
[WS-CLEANUP] Deleting project workspace...
[WS-CLEANUP] Deferred wipeout is used...
[WS-CLEANUP] Done
No credentials specified
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-trunk-jdk11/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision e018bfe2b050b55b479bbabb9fc26ebcc211b177 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f e018bfe2b050b55b479bbabb9fc26ebcc211b177
Commit message: "KAFKA-3522: TopologyTestDriver should only return custom stores via untyped getStateStore() method (#6756)"
 > git rev-list --no-walk 9077d83672a4d08273ce4a6012f1787f5313f948 # timeout=10
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: No tool found matching GRADLE_4_10_2_HOME
[kafka-trunk-jdk11] $ /bin/bash -xe /tmp/jenkins1498054947207275964.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk11/ws/.gradle>
+ /bin/gradle
/tmp/jenkins1498054947207275964.sh: line 4: /bin/gradle: No such file or directory
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
ERROR: No tool found matching GRADLE_4_10_2_HOME
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #540

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

Changes:

[github] MINOR: Add select changes from 3rd KIP-307 PR for incrementing name

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H24 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk11/ws/>
[WS-CLEANUP] Deleting project workspace...
[WS-CLEANUP] Deferred wipeout is used...
[WS-CLEANUP] Done
No credentials specified
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-trunk-jdk11/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 9077d83672a4d08273ce4a6012f1787f5313f948 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 9077d83672a4d08273ce4a6012f1787f5313f948
Commit message: "MINOR: Add select changes from 3rd KIP-307 PR for incrementing name index counter (#6754)"
 > git rev-list --no-walk 16769d263e2e8fd91704d2e3519abf9dcba507df # timeout=10
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: No tool found matching GRADLE_4_10_2_HOME
[kafka-trunk-jdk11] $ /bin/bash -xe /tmp/jenkins5756038469471249256.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk11/ws/.gradle>
+ /bin/gradle
/tmp/jenkins5756038469471249256.sh: line 4: /bin/gradle: No such file or directory
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
ERROR: No tool found matching GRADLE_4_10_2_HOME
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #539

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

Changes:

[bbejeck] KAFKA-8215: Upgrade Rocks to v5.18.3 (#6743)

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk11/ws/>
[WS-CLEANUP] Deleting project workspace...
[WS-CLEANUP] Deferred wipeout is used...
[WS-CLEANUP] Done
No credentials specified
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-trunk-jdk11/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
ERROR: Timeout after 10 minutes
ERROR: Error cloning remote repo 'origin'
hudson.plugins.git.GitException: Command "git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*" returned status code 128:
stdout: 
stderr: remote: Enumerating objects: 50, done.        
remote: Counting objects:   2% (1/50)           remote: Counting objects:   4% (2/50)           remote: Counting objects:   6% (3/50)           remote: Counting objects:   8% (4/50)           remote: Counting objects:  10% (5/50)           remote: Counting objects:  12% (6/50)           remote: Counting objects:  14% (7/50)           remote: Counting objects:  16% (8/50)           remote: Counting objects:  18% (9/50)           remote: Counting objects:  20% (10/50)           remote: Counting objects:  22% (11/50)           remote: Counting objects:  24% (12/50)           remote: Counting objects:  26% (13/50)           remote: Counting objects:  28% (14/50)           remote: Counting objects:  30% (15/50)           remote: Counting objects:  32% (16/50)           remote: Counting objects:  34% (17/50)           remote: Counting objects:  36% (18/50)           remote: Counting objects:  38% (19/50)           remote: Counting objects:  40% (20/50)           remote: Counting objects:  42% (21/50)           remote: Counting objects:  44% (22/50)           remote: Counting objects:  46% (23/50)           remote: Counting objects:  48% (24/50)           remote: Counting objects:  50% (25/50)           remote: Counting objects:  52% (26/50)           remote: Counting objects:  54% (27/50)           remote: Counting objects:  56% (28/50)           remote: Counting objects:  58% (29/50)           remote: Counting objects:  60% (30/50)           remote: Counting objects:  62% (31/50)           remote: Counting objects:  64% (32/50)           remote: Counting objects:  66% (33/50)           remote: Counting objects:  68% (34/50)           remote: Counting objects:  70% (35/50)           remote: Counting objects:  72% (36/50)           remote: Counting objects:  74% (37/50)           remote: Counting objects:  76% (38/50)           remote: Counting objects:  78% (39/50)           remote: Counting objects:  80% (40/50)           remote: Counting objects:  82% (41/50)           remote: Counting objects:  84% (42/50)           remote: Counting objects:  86% (43/50)           remote: Counting objects:  88% (44/50)           remote: Counting objects:  90% (45/50)           remote: Counting objects:  92% (46/50)           remote: Counting objects:  94% (47/50)           remote: Counting objects:  96% (48/50)           remote: Counting objects:  98% (49/50)           remote: Counting objects: 100% (50/50)           remote: Counting objects: 100% (50/50), done.        
remote: Compressing objects:   2% (1/34)           remote: Compressing objects:   5% (2/34)           remote: Compressing objects:   8% (3/34)           remote: Compressing objects:  11% (4/34)           remote: Compressing objects:  14% (5/34)           remote: Compressing objects:  17% (6/34)           remote: Compressing objects:  20% (7/34)           remote: Compressing objects:  23% (8/34)           remote: Compressing objects:  26% (9/34)           remote: Compressing objects:  29% (10/34)           remote: Compressing objects:  32% (11/34)           remote: Compressing objects:  35% (12/34)           remote: Compressing objects:  38% (13/34)           remote: Compressing objects:  41% (14/34)           remote: Compressing objects:  44% (15/34)           remote: Compressing objects:  47% (16/34)           remote: Compressing objects:  50% (17/34)           remote: Compressing objects:  52% (18/34)           remote: Compressing objects:  55% (19/34)           remote: Compressing objects:  58% (20/34)           remote: Compressing objects:  61% (21/34)           remote: Compressing objects:  64% (22/34)           remote: Compressing objects:  67% (23/34)           remote: Compressing objects:  70% (24/34)           remote: Compressing objects:  73% (25/34)           remote: Compressing objects:  76% (26/34)           remote: Compressing objects:  79% (27/34)           remote: Compressing objects:  82% (28/34)           remote: Compressing objects:  85% (29/34)           remote: Compressing objects:  88% (30/34)           remote: Compressing objects:  91% (31/34)           remote: Compressing objects:  94% (32/34)           remote: Compressing objects:  97% (33/34)           remote: Compressing objects: 100% (34/34)           remote: Compressing objects: 100% (34/34), done.        
Receiving objects:   0% (1/170190)   Receiving objects:   0% (216/170190), 60.01 KiB | 95.00 KiB/s   Receiving objects:   0% (488/170190), 172.01 KiB | 96.00 KiB/s   Receiving objects:   0% (694/170190), 276.01 KiB | 94.00 KiB/s   Receiving objects:   0% (786/170190), 316.01 KiB | 85.00 KiB/s   Receiving objects:   0% (894/170190), 372.01 KiB | 76.00 KiB/s   Receiving objects:   0% (1031/170190), 404.01 KiB | 72.00 KiB/s   Receiving objects:   0% (1246/170190), 492.01 KiB | 69.00 KiB/s   Receiving objects:   0% (1517/170190), 620.01 KiB | 70.00 KiB/s   Receiving objects:   0% (1692/170190), 708.01 KiB | 73.00 KiB/s   Receiving objects:   1% (1702/170190), 708.01 KiB | 73.00 KiB/s   Receiving objects:   1% (1929/170190), 756.01 KiB | 76.00 KiB/s   Receiving objects:   1% (2167/170190), 884.01 KiB | 92.00 KiB/s   Receiving objects:   1% (2234/170190), 940.01 KiB | 84.00 KiB/s   Receiving objects:   1% (2574/170190), 1004.01 KiB | 84.00 KiB/s   Receiving objects:   1% (2827/170190), 1.14 MiB | 92.00 KiB/s   Receiving objects:   1% (3056/170190), 1.25 MiB | 98.00 KiB/s   Receiving objects:   1% (3324/170190), 1.36 MiB | 95.00 KiB/s   Receiving objects:   2% (3404/170190), 1.36 MiB | 95.00 KiB/s   Receiving objects:   2% (3638/170190), 1.44 MiB | 106.00 KiB/s   Receiving objects:   2% (3845/170190), 1.53 MiB | 106.00 KiB/s   Receiving objects:   2% (4188/170190), 1.65 MiB | 100.00 KiB/s   Receiving objects:   2% (4516/170190), 1.74 MiB | 110.00 KiB/s   Receiving objects:   2% (4736/170190), 1.85 MiB | 106.00 KiB/s   Receiving objects:   2% (4867/170190), 1.92 MiB | 91.00 KiB/s   Receiving objects:   3% (5106/170190), 1.98 MiB | 96.00 KiB/s   Receiving objects:   3% (5267/170190), 2.06 MiB | 103.00 KiB/s   Receiving objects:   3% (5657/170190), 2.14 MiB | 106.00 KiB/s   Receiving objects:   3% (5857/170190), 2.25 MiB | 95.00 KiB/s   Receiving objects:   3% (6204/170190), 2.39 MiB | 101.00 KiB/s   Receiving objects:   3% (6588/170190), 2.46 MiB | 112.00 KiB/s   Receiving objects:   4% (6808/170190), 2.54 MiB | 120.00 KiB/s   Receiving objects:   4% (7066/170190), 2.62 MiB | 124.00 KiB/s   Receiving objects:   4% (7692/170190), 2.84 MiB | 137.00 KiB/s   Receiving objects:   4% (8334/170190), 3.00 MiB | 152.00 KiB/s   Receiving objects:   5% (8510/170190), 3.00 MiB | 152.00 KiB/s   Receiving objects:   5% (8972/170190), 3.15 MiB | 157.00 KiB/s   Receiving objects:   5% (9195/170190), 3.21 MiB | 151.00 KiB/s   Receiving objects:   5% (9382/170190), 3.32 MiB | 145.00 KiB/s   Receiving objects:   5% (9477/170190), 3.48 MiB | 126.00 KiB/s   Receiving objects:   5% (9533/170190), 3.53 MiB | 113.00 KiB/s   Receiving objects:   5% (9570/170190), 3.61 MiB | 99.00 KiB/s   Receiving objects:   5% (9622/170190), 3.66 MiB | 94.00 KiB/s   Receiving objects:   5% (9744/170190), 3.81 MiB | 100.00 KiB/s   Receiving objects:   5% (9970/170190), 3.96 MiB | 105.00 KiB/s   Receiving objects:   5% (10110/170190), 4.07 MiB | 107.00 KiB/s   Receiving objects:   6% (10212/170190), 4.14 MiB | 110.00 KiB/s   Receiving objects:   6% (10225/170190), 4.14 MiB | 110.00 KiB/s   Receiving objects:   6% (10316/170190), 4.25 MiB | 114.00 KiB/s   Receiving objects:   6% (10443/170190), 4.39 MiB | 113.00 KiB/s   Receiving objects:   6% (10523/170190), 4.48 MiB | 98.00 KiB/s   Receiving objects:   6% (10590/170190), 4.51 MiB | 89.00 KiB/s   Receiving objects:   6% (10686/170190), 4.56 MiB | 89.00 KiB/s   Receiving objects:   6% (10821/170190), 4.67 MiB | 90.00 KiB/s   Receiving objects:   6% (10904/170190), 4.74 MiB | 72.00 KiB/s   Receiving objects:   6% (10945/170190), 4.76 MiB | 64.00 KiB/s   Receiving objects:   6% (11154/170190), 4.90 MiB | 75.00 KiB/s   Receiving objects:   6% (11196/170190), 4.98 MiB | 78.00 KiB/s   Receiving objects:   6% (11241/170190), 5.03 MiB | 79.00 KiB/s   Receiving objects:   6% (11289/170190), 5.11 MiB | 77.00 KiB/s   Receiving objects:   6% (11354/170190), 5.18 MiB | 80.00 KiB/s   Receiving objects:   6% (11390/170190), 5.23 MiB | 70.00 KiB/s   Receiving objects:   6% (11480/170190), 5.28 MiB | 68.00 KiB/s   Receiving objects:   6% (11555/170190), 5.39 MiB | 74.00 KiB/s   Receiving objects:   6% (11662/170190), 5.50 MiB | 72.00 KiB/s   Receiving objects:   6% (11755/170190), 5.54 MiB | 74.00 KiB/s   Receiving objects:   6% (11897/170190), 5.62 MiB | 76.00 KiB/s   Receiving objects:   7% (11914/170190), 5.62 MiB | 76.00 KiB/s   Receiving objects:   7% (12148/170190), 5.70 MiB | 87.00 KiB/s   Receiving objects:   7% (12229/170190), 5.86 MiB | 97.00 KiB/s   Receiving objects:   7% (12316/170190), 5.96 MiB | 93.00 KiB/s   Receiving objects:   7% (12461/170190), 6.03 MiB | 98.00 KiB/s   Receiving objects:   7% (12517/170190), 6.12 MiB | 101.00 KiB/s   Receiving objects:   7% (12633/170190), 6.17 MiB | 101.00 KiB/s   Receiving objects:   7% (12775/170190), 6.34 MiB | 99.00 KiB/s   Receiving objects:   7% (12863/170190), 6.47 MiB | 103.00 KiB/s   Receiving objects:   7% (12928/170190), 6.58 MiB | 106.00 KiB/s   Receiving objects:   7% (12954/170190), 6.61 MiB | 101.00 KiB/s   Receiving objects:   7% (12985/170190), 6.70 MiB | 100.00 KiB/s   Receiving objects:   7% (13122/170190), 6.85 MiB | 99.00 KiB/s   Receiving objects:   7% (13152/170190), 6.89 MiB | 92.00 KiB/s   Receiving objects:   7% (13206/170190), 6.95 MiB | 80.00 KiB/s   Receiving objects:   7% (13370/170190), 7.11 MiB | 97.00 KiB/s   Receiving objects:   7% (13450/170190), 7.22 MiB | 104.00 KiB/s   Receiving objects:   7% (13541/170190), 7.27 MiB | 101.00 KiB/s   Receiving objects:   8% (13616/170190), 7.34 MiB | 98.00 KiB/s   Receiving objects:   8% (13682/170190), 7.40 MiB | 104.00 KiB/s   Receiving objects:   8% (13740/170190), 7.50 MiB | 110.00 KiB/s   Receiving objects:   8% (13811/170190), 7.59 MiB | 98.00 KiB/s   Receiving objects:   8% (13854/170190), 7.63 MiB | 92.00 KiB/s   Receiving objects:   8% (13935/170190), 7.71 MiB | 87.00 KiB/s   Receiving objects:   8% (13982/170190), 7.81 MiB | 77.00 KiB/s   Receiving objects:   8% (14139/170190), 7.86 MiB | 77.00 KiB/s   Receiving objects:   8% (14209/170190), 8.09 MiB | 99.00 KiB/s   Receiving objects:   8% (14210/170190), 8.21 MiB | 109.00 KiB/s   Receiving objects:   8% (14215/170190), 8.31 MiB | 122.00 KiB/s   Receiving objects:   8% (14217/170190), 8.43 MiB | 130.00 KiB/s   Receiving objects:   8% (14219/170190), 8.61 MiB | 137.00 KiB/s   Receiving objects:   8% (14219/170190), 8.74 MiB | 133.00 KiB/s   Receiving objects:   8% (14220/170190), 8.85 MiB | 121.00 KiB/s   Receiving objects:   8% (14220/170190), 8.91 MiB | 114.00 KiB/s   Receiving objects:   8% (14222/170190), 8.99 MiB | 113.00 KiB/s   Receiving objects:   8% (14223/170190), 9.13 MiB | 118.00 KiB/s   Receiving objects:   8% (14223/170190), 9.25 MiB | 108.00 KiB/s   Receiving objects:   8% (14225/170190), 9.37 MiB | 109.00 KiB/s   Receiving objects:   8% (14227/170190), 9.44 MiB | 120.00 KiB/s   Receiving objects:   8% (14228/170190), 9.63 MiB | 118.00 KiB/s   Receiving objects:   8% (14229/170190), 9.73 MiB | 109.00 KiB/s   Receiving objects:   8% (14230/170190), 9.79 MiB | 105.00 KiB/s   Receiving objects:   8% (14231/170190), 9.86 MiB | 101.00 KiB/s   Receiving objects:   8% (14233/170190), 10.00 MiB | 96.00 KiB/s   Receiving objects:   8% (14233/170190), 10.04 MiB | 89.00 KiB/s   Receiving objects:   8% (14236/170190), 10.10 MiB | 86.00 KiB/s   Receiving objects:   8% (14236/170190), 10.21 MiB | 87.00 KiB/s   Receiving objects:   8% (14238/170190), 10.32 MiB | 84.00 KiB/s   Receiving objects:   8% (14240/170190), 10.36 MiB | 88.00 KiB/s   Receiving objects:   8% (14241/170190), 10.43 MiB | 86.00 KiB/s   Receiving objects:   8% (14242/170190), 10.54 MiB | 91.00 KiB/s   Receiving objects:   8% (14242/170190), 10.61 MiB | 81.00 KiB/s   Receiving objects:   8% (14244/170190), 10.66 MiB | 81.00 KiB/s   Receiving objects:   8% (14245/170190), 10.80 MiB | 86.00 KiB/s   Receiving objects:   8% (14246/170190), 10.84 MiB | 82.00 KiB/s   Receiving objects:   8% (14273/170190), 10.93 MiB | 78.00 KiB/s   Receiving objects:   8% (14297/170190), 11.00 MiB | 77.00 KiB/s   Receiving objects:   8% (14336/170190), 11.07 MiB | 84.00 KiB/s   Receiving objects:   8% (14493/170190), 11.25 MiB | 100.00 KiB/s   Receiving objects:   8% (14662/170190), 11.38 MiB | 106.00 KiB/s   Receiving objects:   8% (14779/170190), 11.44 MiB | 108.00 KiB/s   Receiving objects:   8% (14910/170190), 11.56 MiB | 113.00 KiB/s   Receiving objects:   8% (15008/170190), 11.62 MiB | 103.00 KiB/s   Receiving objects:   8% (15155/170190), 11.66 MiB | 92.00 KiB/s   Receiving objects:   8% (15235/170190), 11.75 MiB | 79.00 KiB/s   Receiving objects:   8% (15308/170190), 11.83 MiB | 74.00 KiB/s   Receiving objects:   9% (15318/170190), 11.83 MiB | 74.00 KiB/s   Receiving objects:   9% (15364/170190), 11.86 MiB | 66.00 KiB/s   Receiving objects:   9% (15506/170190), 11.99 MiB | 75.00 KiB/s   Receiving objects:   9% (15584/170190), 12.07 MiB | 75.00 KiB/s   Receiving objects:   9% (15657/170190), 12.10 MiB | 72.00 KiB/s   Receiving objects:   9% (15743/170190), 12.14 MiB | 66.00 KiB/s   Receiving objects:   9% (15789/170190), 12.18 MiB | 65.00 KiB/s   Receiving objects:   9% (15893/170190), 12.30 MiB | 74.00 KiB/s   Receiving objects:   9% (15978/170190), 12.39 MiB | 66.00 KiB/s   Receiving objects:   9% (16038/170190), 12.43 MiB | 64.00 KiB/s   Receiving objects:   9% (16150/170190), 12.52 MiB | 67.00 KiB/s   Receiving objects:   9% (16235/170190), 12.60 MiB | 78.00 KiB/s   Receiving objects:   9% (16284/170190), 12.66 MiB | 72.00 KiB/s   Receiving objects:   9% (16331/170190), 12.68 MiB | 66.00 KiB/s   Receiving objects:   9% (16460/170190), 12.80 MiB | 74.00 KiB/s   Receiving objects:   9% (16662/170190), 12.96 MiB | 89.00 KiB/s   Receiving objects:   9% (16954/170190), 13.04 MiB | 96.00 KiB/s   Receiving objects:  10% (17019/170190), 13.11 MiB | 95.00 KiB/s   Receiving objects:  10% (17061/170190), 13.14 MiB | 97.00 KiB/s   Receiving objects:  10% (17279/170190), 13.30 MiB | 120.00 KiB/s   Receiving objects:  10% (17501/170190), 13.39 MiB | 127.00 KiB/s   Receiving objects:  10% (17669/170190), 13.52 MiB | 124.00 KiB/s   Receiving objects:  10% (17879/170190), 13.73 MiB | 136.00 KiB/s   Receiving objects:  10% (17942/170190), 13.85 MiB | 137.00 KiB/s   Receiving objects:  10% (18030/170190), 13.94 MiB | 120.00 KiB/s   Receiving objects:  10% (18106/170190), 14.00 MiB | 114.00 KiB/s   Receiving objects:  10% (18373/170190), 14.07 MiB | 111.00 KiB/s   Receiving objects:  10% (18477/170190), 14.19 MiB | 107.00 KiB/s   Receiving objects:  10% (18644/170190), 14.32 MiB | 95.00 KiB/s   Receiving objects:  11% (18721/170190), 14.36 MiB | 97.00 KiB/s   Receiving objects:  11% (18827/170190), 14.43 MiB | 101.00 KiB/s   Receiving objects:  11% (18903/170190), 14.50 MiB | 107.00 KiB/s   Receiving objects:  11% (18975/170190), 14.58 MiB | 101.00 KiB/s   Receiving objects:  11% (19095/170190), 14.75 MiB | 109.00 KiB/s   Receiving objects:  11% (19249/170190), 14.88 MiB | 114.00 KiB/s   Receiving objects:  11% (19344/170190), 14.93 MiB | 115.00 KiB/s   Receiving objects:  11% (19414/170190), 15.02 MiB | 99.00 KiB/s   Receiving objects:  11% (19750/170190), 15.08 MiB | 100.00 KiB/s   Receiving objects:  11% (19936/170190), 15.21 MiB | 99.00 KiB/s   Receiving objects:  11% (20086/170190), 15.30 MiB | 85.00 KiB/s   Receiving objects:  11% (20162/170190), 15.35 MiB | 82.00 KiB/s   Receiving objects:  12% (20423/170190), 15.41 MiB | 83.00 KiB/s   Receiving objects:  12% (20549/170190), 15.54 MiB | 103.00 KiB/s   Receiving objects:  12% (20789/170190), 15.72 MiB | 116.00 KiB/s   Receiving objects:  12% (20803/170190), 15.75 MiB | 107.00 KiB/s   Receiving objects:  12% (20964/170190), 15.82 MiB | 98.00 KiB/s   Receiving objects:  12% (21086/170190), 15.89 MiB | 106.00 KiB/s   Receiving objects:  12% (21176/170190), 16.00 MiB | 108.00 KiB/s   Receiving objects:  12% (21232/170190), 16.04 MiB | 91.00 KiB/s   Receiving objects:  12% (21256/170190), 16.08 MiB | 72.00 KiB/s   Receiving objects:  12% (21295/170190), 16.16 MiB | 69.00 KiB/s   Receiving objects:  12% (21399/170190), 16.21 MiB | 69.00 KiB/s   Receiving objects:  12% (21654/170190), 16.37 MiB | 83.00 KiB/s   Receiving objects:  12% (21909/170190), 16.54 MiB | 93.00 KiB/s   Receiving objects:  12% (22020/170190), 16.66 MiB | 113.00 KiB/s   Receiving objects:  13% (22125/170190), 16.74 MiB | 121.00 KiB/s   Receiving objects:  13% (22165/170190), 16.74 MiB | 121.00 KiB/s   Receiving objects:  13% (22216/170190), 16.85 MiB | 124.00 KiB/s   Receiving objects:  13% (22380/170190), 16.89 MiB | 116.00 KiB/s   Receiving objects:  13% (22410/170190), 16.99 MiB | 95.00 KiB/s   Receiving objects:  13% (22445/170190), 17.02 MiB | 86.00 KiB/s   Receiving objects:  13% (22503/170190), 17.11 MiB | 78.00 KiB/s   Receiving objects:  13% (22597/170190), 17.21 MiB | 73.00 KiB/s   Receiving objects:  13% (22694/170190), 17.33 MiB | 82.00 KiB/s   Receiving objects:  13% (22813/170190), 17.39 MiB | 84.00 KiB/s   Receiving objects:  13% (22860/170190), 17.45 MiB | 82.00 KiB/s   Receiving objects:  13% (22952/170190), 17.49 MiB | 81.00 KiB/s   Receiving objects:  13% (23090/170190), 17.58 MiB | 82.00 KiB/s   Receiving objects:  13% (23332/170190), 17.64 MiB | 82.00 KiB/s   Receiving objects:  13% (23507/170190), 17.81 MiB | 89.00 KiB/s   Receiving objects:  13% (23736/170190), 17.99 MiB | 109.00 KiB/s   Receiving objects:  14% (23827/170190), 18.04 MiB | 113.00 KiB/s   Receiving objects:  14% (23928/170190), 18.09 MiB | 118.00 KiB/s   Receiving objects:  14% (23968/170190), 18.14 MiB | 118.00 KiB/s   Receiving objects:  14% (24076/170190), 18.21 MiB | 108.00 KiB/s   Receiving objects:  14% (24220/170190), 18.32 MiB | 93.00 KiB/s   Receiving objects:  14% (24266/170190), 18.36 MiB | 85.00 KiB/s   Receiving objects:  14% (24331/170190), 18.46 MiB | 74.00 KiB/s   Receiving objects:  14% (24408/170190), 18.50 MiB | 72.00 KiB/s   Receiving objects:  14% (24543/170190), 18.63 MiB | 78.00 KiB/s   Receiving objects:  14% (24644/170190), 18.68 MiB | 82.00 KiB/s   Receiving objects:  14% (24767/170190), 18.79 MiB | 82.00 KiB/s   Receiving objects:  14% (24882/170190), 18.89 MiB | 87.00 KiB/s   Receiving objects:  14% (25005/170190), 18.99 MiB | 90.00 KiB/s   Receiving objects:  14% (25118/170190), 19.05 MiB | 88.00 KiB/s   Receiving objects:  14% (25268/170190), 19.10 MiB | 85.00 KiB/s   Receiving objects:  14% (25398/170190), 19.22 MiB | 91.00 KiB/s   Receiving objects:  15% (25529/170190), 19.32 MiB | 91.00 KiB/s   Receiving objects:  15% (25530/170190), 19.32 MiB | 91.00 KiB/s   Receiving objects:  15% (25769/170190), 19.47 MiB | 101.00 KiB/s   Receiving objects:  15% (25868/170190), 19.56 MiB | 109.00 KiB/s   Receiving objects:  15% (25970/170190), 19.65 MiB | 106.00 KiB/s   Receiving objects:  15% (26111/170190), 19.76 MiB | 104.00 KiB/s   Receiving objects:  15% (26324/170190), 19.86 MiB | 101.00 KiB/s   Receiving objects:  15% (26400/170190), 19.89 MiB | 90.00 KiB/s   Receiving objects:  15% (26458/170190), 19.95 MiB | 89.00 KiB/s   Receiving objects:  15% (26508/170190), 20.03 MiB | 75.00 KiB/s   Receiving objects:  15% (26549/170190), 20.07 MiB | 75.00 KiB/s   Receiving objects:  15% (26649/170190), 20.17 MiB | 69.00 KiB/s   Receiving objects:  15% (26717/170190), 20.21 MiB | 62.00 KiB/s   Receiving objects:  15% (26808/170190), 20.25 MiB | 62.00 KiB/s   Receiving objects:  15% (26827/170190), 20.32 MiB | 56.00 KiB/s   Receiving objects:  15% (26990/170190), 20.37 MiB | 59.00 KiB/s   Receiving objects:  15% (27089/170190), 20.45 MiB | 59.00 KiB/s   Receiving objects:  15% (27180/170190), 20.48 MiB | 57.00 KiB/s   Receiving objects:  16% (27231/170190), 20.48 MiB | 57.00 KiB/s   Receiving objects:  16% (27492/170190), 20.61 MiB | 72.00 KiB/s   Receiving objects:  16% (27772/170190), 20.74 MiB | 85.00 KiB/s   Receiving objects:  16% (28243/170190), 20.84 MiB | 93.00 KiB/s   Receiving objects:  16% (28513/170190), 20.93 MiB | 97.00 KiB/s   Receiving objects:  16% (28698/170190), 20.96 MiB | 93.00 KiB/s   Receiving objects:  17% (28933/170190), 21.01 MiB | 91.00 KiB/s   Receiving objects:  17% (28972/170190), 21.01 MiB | 91.00 KiB/s   Receiving objects:  17% (29326/170190), 21.11 MiB | 75.00 KiB/s   Receiving objects:  17% (29726/170190), 21.15 MiB | 72.00 KiB/s   Receiving objects:  17% (30144/170190), 21.26 MiB | 67.00 KiB/s   Receiving objects:  17% (30360/170190), 21.31 MiB | 68.00 KiB/s   Receiving objects:  17% (30587/170190), 21.44 MiB | 81.00 KiB/s   Receiving objects:  18% (30635/170190), 21.44 MiB | 81.00 KiB/s   Receiving objects:  18% (30716/170190), 21.50 MiB | 82.00 KiB/s   Receiving objects:  18% (30967/170190), 21.61 MiB | 89.00 KiB/s   Receiving objects:  18% (31501/170190), 21.74 MiB | 96.00 KiB/s   Receiving objects:  18% (31714/170190), 21.80 MiB | 98.00 KiB/s   Receiving objects:  18% (31853/170190), 21.87 MiB | 85.00 KiB/s   Receiving objects:  18% (31990/170190), 21.90 MiB | 83.00 KiB/s   Receiving objects:  18% (32254/170190), 22.00 MiB | 81.00 KiB/s   Receiving objects:  19% (32337/170190), 22.00 MiB | 81.00 KiB/s   Receiving objects:  19% (32603/170190), 22.14 MiB | 91.00 KiB/s   Receiving objects:  19% (32813/170190), 22.20 MiB | 82.00 KiB/s   Receiving objects:  19% (33189/170190), 22.29 MiB | 85.00 KiB/s   Receiving objects:  19% (33320/170190), 22.32 MiB | 84.00 KiB/s   Receiving objects:  19% (33514/170190), 22.42 MiB | 87.00 KiB/s   Receiving objects:  19% (33737/170190), 22.56 MiB | 89.00 KiB/s   Receiving objects:  19% (34011/170190), 22.65 MiB | 90.00 KiB/s   Receiving objects:  20% (34038/170190), 22.65 MiB | 90.00 KiB/s   Receiving objects:  20% (34157/170190), 22.75 MiB | 91.00 KiB/s   Receiving objects:  20% (34260/170190), 22.79 MiB | 93.00 KiB/s   Receiving objects:  20% (34296/170190), 22.86 MiB | 82.00 KiB/s   Receiving objects:  20% (34396/170190), 22.89 MiB | 72.00 KiB/s   Receiving objects:  20% (34483/170190), 22.98 MiB | 68.00 KiB/s   Receiving objects:  20% (34597/170190), 23.03 MiB | 65.00 KiB/s   Receiving objects:  20% (34686/170190), 23.11 MiB | 62.00 KiB/s   Receiving objects:  20% (34921/170190), 23.18 MiB | 68.00 KiB/s   Receiving objects:  20% (35120/170190), 23.25 MiB | 72.00 KiB/s   Receiving objects:  20% (35297/170190), 23.29 MiB | 71.00 KiB/s   Receiving objects:  20% (35395/170190), 23.36 MiB | 65.00 KiB/s   Receiving objects:  20% (35525/170190), 23.42 MiB | 64.00 KiB/s   Receiving objects:  20% (35665/170190), 23.46 MiB | 49.00 KiB/s   Receiving objects:  20% (35725/170190), 23.50 MiB | 49.00 KiB/s   Receiving objects:  21% (35740/170190), 23.50 MiB | 49.00 KiB/s   Receiving objects:  21% (35889/170190), 23.57 MiB | 50.00 KiB/s   Receiving objects:  21% (36089/170190), 23.59 MiB | 50.00 KiB/s   Receiving objects:  21% (36317/170190), 23.64 MiB | 49.00 KiB/s   Receiving objects:  21% (36562/170190), 23.73 MiB | 54.00 KiB/s   Receiving objects:  21% (36769/170190), 23.78 MiB | 58.00 KiB/s   Receiving objects:  21% (36830/170190), 23.84 MiB | 62.00 KiB/s   Receiving objects:  21% (36962/170190), 23.94 MiB | 67.00 KiB/s   Receiving objects:  21% (37104/170190), 24.01 MiB | 73.00 KiB/s   Receiving objects:  21% (37189/170190), 24.07 MiB | 72.00 KiB/s   Receiving objects:  21% (37263/170190), 24.11 MiB | 65.00 KiB/s   Receiving objects:  21% (37371/170190), 24.15 MiB | 67.00 KiB/s   Receiving objects:  22% (37442/170190), 24.23 MiB | 72.00 KiB/s   Receiving objects:  22% (37613/170190), 24.32 MiB | 80.00 KiB/s   Receiving objects:  22% (37823/170190), 24.42 MiB | 84.00 KiB/s   Receiving objects:  22% (37941/170190), 24.54 MiB | 90.00 KiB/s   Receiving objects:  22% (38156/170190), 24.61 MiB | 103.00 KiB/s   Receiving objects:  22% (38288/170190), 24.75 MiB | 119.00 KiB/s   Receiving objects:  22% (38436/170190), 24.87 MiB | 104.00 KiB/s   Receiving objects:  22% (38552/170190), 24.95 MiB | 106.00 KiB/s   Receiving objects:  22% (38613/170190), 25.02 MiB | 98.00 KiB/s   Receiving objects:  22% (38697/170190), 25.04 MiB | 90.00 KiB/s   Receiving objects:  22% (38754/170190), 25.11 MiB | 72.00 KiB/s   Receiving objects:  22% (38802/170190), 25.14 MiB | 67.00 KiB/s   Receiving objects:  22% (38928/170190), 25.23 MiB | 63.00 KiB/s   Receiving objects:  22% (39010/170190), 25.32 MiB | 57.00 KiB/s   Receiving objects:  23% (39144/170190), 25.37 MiB | 64.00 KiB/s   Receiving objects:  23% (39209/170190), 25.40 MiB | 66.00 KiB/s   Receiving objects:  23% (39284/170190), 25.43 MiB | 67.00 KiB/s   Receiving objects:  23% (39432/170190), 25.51 MiB | 69.00 KiB/s   Receiving objects:  23% (39501/170190), 25.57 MiB | 63.00 KiB/s   Receiving objects:  23% (39548/170190), 25.62 MiB | 61.00 KiB/s   Receiving objects:  23% (39614/170190), 25.65 MiB | 58.00 KiB/s   Receiving objects:  23% (39693/170190), 25.71 MiB | 54.00 KiB/s   Receiving objects:  23% (39808/170190), 25.79 MiB | 55.00 KiB/s   Receiving objects:  23% (39885/170190), 25.83 MiB | 59.00 KiB/s   Receiving objects:  23% (39945/170190), 25.90 MiB | 59.00 KiB/s   Receiving objects:  23% (40083/170190), 25.96 MiB | 65.00 KiB/s   Receiving objects:  23% (40204/170190), 26.07 MiB | 73.00 KiB/s   Receiving objects:  23% (40247/170190), 26.11 MiB | 73.00 KiB/s   Receiving objects:  23% (40343/170190), 26.18 MiB | 68.00 KiB/s   Receiving objects:  23% (40493/170190), 26.21 MiB | 65.00 KiB/s   Receiving objects:  23% (40691/170190), 26.34 MiB | 76.00 KiB/s   Receiving objects:  24% (40846/170190), 26.42 MiB | 78.00 KiB/s   Receiving objects:  24% (40890/170190), 26.42 MiB | 78.00 KiB/s   Receiving objects:  24% (41027/170190), 26.51 MiB | 77.00 KiB/s   Receiving objects:  24% (41116/170190), 26.62 MiB | 82.00 KiB/s   Receiving objects:  24% (41217/170190), 26.68 MiB | 90.00 KiB/s   Receiving objects:  24% (41312/170190), 26.76 MiB | 86.00 KiB/s   Receiving objects:  24% (41437/170190), 26.81 MiB | 84.00 KiB/s   Receiving objects:  24% (41714/170190), 26.93 MiB | 82.00 KiB/s   Receiving objects:  24% (41907/170190), 27.06 MiB | 97.00 KiB/s   Receiving objects:  24% (42141/170190), 27.21 MiB | 103.00 KiB/s   Receiving objects:  24% (42327/170190), 27.25 MiB | 108.00 KiB/s   Receiving objects:  24% (42471/170190), 27.34 MiB | 101.00 KiB/s   Receiving objects:  25% (42548/170190), 27.34 MiB | 101.00 KiB/s   Receiving objects:  25% (42806/170190), 27.46 MiB | 101.00 KiB/s   Receiving objects:  25% (43183/170190), 27.54 MiB | 100.00 KiB/s   Receiving objects:  25% (43776/170190), 27.65 MiB | 98.00 KiB/s   Receiving objects:  26% (44250/170190), 27.75 MiB | 102.00 KiB/s   Receiving objects:  26% (44476/170190), 27.82 MiB | 108.00 KiB/s   Receiving objects:  26% (44735/170190), 27.87 MiB | 112.00 KiB/s   Receiving objects:  26% (44960/170190), 27.95 MiB | 110.00 KiB/s   Receiving objects:  26% (45193/170190), 28.04 MiB | 100.00 KiB/s   Receiving objects:  26% (45318/170190), 28.11 MiB | 86.00 KiB/s   Receiving objects:  26% (45812/170190), 28.18 MiB | 83.00 KiB/s   Receiving objects:  27% (45952/170190), 28.28 MiB | 88.00 KiB/s   Receiving objects:  27% (46168/170190), 28.35 MiB | 91.00 KiB/s   Receiving objects:  27% (46303/170190), 28.39 MiB | 83.00 KiB/s   Receiving objects:  27% (46465/170190), 28.48 MiB | 87.00 KiB/s   Receiving objects:  27% (46543/170190), 28.54 MiB | 83.00 KiB/s   Receiving objects:  27% (46606/170190), 28.57 MiB | 82.00 KiB/s   Receiving objects:  27% (46802/170190), 28.63 MiB | 78.00 KiB/s   Receiving objects:  27% (46998/170190), 28.78 MiB | 75.00 KiB/s   Receiving objects:  27% (47104/170190), 28.93 MiB | 94.00 KiB/s   Receiving objects:  27% (47174/170190), 28.98 MiB | 92.00 KiB/s   Receiving objects:  27% (47293/170190), 29.10 MiB | 101.00 KiB/s   Receiving objects:  27% (47336/170190), 29.14 MiB | 95.00 KiB/s   Receiving objects:  27% (47438/170190), 29.18 MiB | 88.00 KiB/s   Receiving objects:  27% (47634/170190), 29.29 MiB | 78.00 KiB/s   Receiving objects:  28% (47654/170190), 29.29 MiB | 78.00 KiB/s   Receiving objects:  28% (47793/170190), 29.40 MiB | 80.00 KiB/s   Receiving objects:  28% (47936/170190), 29.46 MiB | 74.00 KiB/s   Receiving objects:  28% (48003/170190), 29.49 MiB | 72.00 KiB/s   Receiving objects:  28% (48130/170190), 29.61 MiB | 81.00 KiB/s   Receiving objects:  28% (48287/170190), 29.66 MiB | 81.00 KiB/s   Receiving objects:  28% (48614/170190), 29.82 MiB | 87.00 KiB/s   Receiving objects:  28% (48692/170190), 29.93 MiB | 91.00 KiB/s   Receiving objects:  28% (48779/170190), 29.97 MiB | 93.00 KiB/s   Receiving objects:  28% (48905/170190), 30.02 MiB | 94.00 KiB/s   Receiving objects:  28% (49183/170190), 30.14 MiB | 98.00 KiB/s   Receiving objects:  29% (49356/170190), 30.21 MiB | 100.00 KiB/s   Receiving objects:  29% (49425/170190), 30.29 MiB | 97.00 KiB/s   Receiving objects:  29% (49645/170190), 30.35 MiB | 92.00 KiB/s   Receiving objects:  29% (50002/170190), 30.47 MiB | 94.00 KiB/s   Receiving objects:  29% (50151/170190), 30.55 MiB | 100.00 KiB/s   Receiving objects:  29% (50448/170190), 30.60 MiB | 97.00 KiB/s   Receiving objects:  29% (50690/170190), 30.74 MiB | 99.00 KiB/s   Receiving objects:  29% (50838/170190), 30.85 MiB | 99.00 KiB/s   Receiving objects:  29% (50926/170190), 30.96 MiB | 96.00 KiB/s   Receiving objects:  29% (51030/170190), 31.00 MiB | 92.00 KiB/s   Receiving objects:  30% (51057/170190), 31.05 MiB | 92.00 KiB/s   Receiving objects:  30% (51094/170190), 31.08 MiB | 87.00 KiB/s   Receiving objects:  30% (51225/170190), 31.14 MiB | 83.00 KiB/s   Receiving objects:  30% (51311/170190), 31.23 MiB | 80.00 KiB/s   Receiving objects:  30% (51401/170190), 31.29 MiB | 76.00 KiB/s   Receiving objects:  30% (51466/170190), 31.35 MiB | 68.00 KiB/s   Receiving objects:  30% (51666/170190), 31.44 MiB | 71.00 KiB/s   Receiving objects:  30% (51747/170190), 31.49 MiB | 73.00 KiB/s   Receiving objects:  30% (51891/170190), 31.54 MiB | 71.00 KiB/s   Receiving objects:  30% (52071/170190), 31.64 MiB | 74.00 KiB/s   Receiving objects:  30% (52183/170190), 31.71 MiB | 70.00 KiB/s   Receiving objects:  30% (52353/170190), 31.75 MiB | 72.00 KiB/s   Receiving objects:  30% (52711/170190), 31.97 MiB | 96.00 KiB/s   Receiving objects:  31% (52759/170190), 31.97 MiB | 96.00 KiB/s   Receiving objects:  31% (52904/170190), 32.10 MiB | 107.00 KiB/s   Receiving objects:  31% (53142/170190), 32.26 MiB | 120.00 KiB/s   Receiving objects:  31% (53262/170190), 32.32 MiB | 126.00 KiB/s   Receiving objects:  31% (53395/170190), 32.39 MiB | 126.00 KiB/s   Receiving objects:  31% (53516/170190), 32.46 MiB | 92.00 KiB/s   Receiving objects:  31% (53804/170190), 32.57 MiB | 88.00 KiB/s   Receiving objects:  31% (53942/170190), 32.62 MiB | 85.00 KiB/s   Receiving objects:  31% (54076/170190), 32.68 MiB | 77.00 KiB/s   Receiving objects:  31% (54188/170190), 32.77 MiB | 75.00 KiB/s   Receiving objects:  31% (54357/170190), 32.89 MiB | 90.00 KiB/s   Receiving objects:  32% (54461/170190), 32.97 MiB | 102.00 KiB/s   Receiving objects:  32% (54574/170190), 33.04 MiB | 104.00 KiB/s   Receiving objects:  32% (54988/170190), 33.16 MiB | 111.00 KiB/s   Receiving objects:  32% (55109/170190), 33.24 MiB | 99.00 KiB/s   Receiving objects:  32% (55321/170190), 33.29 MiB | 99.00 KiB/s   Receiving objects:  32% (55633/170190), 33.39 MiB | 93.00 KiB/s   Receiving objects:  32% (55769/170190), 33.43 MiB | 86.00 KiB/s   Receiving objects:  32% (55931/170190), 33.47 MiB | 70.00 KiB/s   Receiving objects:  33% (56163/170190), 33.50 MiB | 64.00 KiB/s   Receiving objects:  33% (56213/170190), 33.57 MiB | 68.00 KiB/s   Receiving objects:  33% (56352/170190), 33.63 MiB | 75.00 KiB/s   Receiving objects:  33% (56516/170190), 33.77 MiB | 85.00 KiB/s   Receiving objects:  33% (56634/170190), 33.89 MiB | 86.00 KiB/s   Receiving objects:  33% (56691/170190), 33.93 MiB | 86.00 KiB/s   Receiving objects:  33% (56790/170190), 34.00 MiB | 91.00 KiB/s   Receiving objects:  33% (56885/170190), 34.05 MiB | 88.00 KiB/s   Receiving objects:  33% (56976/170190), 34.15 MiB | 82.00 KiB/s   Receiving objects:  33% (57151/170190), 34.27 MiB | 80.00 KiB/s   Receiving objects:  33% (57314/170190), 34.33 MiB | 82.00 KiB/s   Receiving objects:  33% (57492/170190), 34.46 MiB | 90.00 KiB/s   Receiving objects:  33% (57536/170190), 34.53 MiB | 88.00 KiB/s   Receiving objects:  33% (57574/170190), 34.58 MiB | 82.00 KiB/s   Receiving objects:  33% (57621/170190), 34.63 MiB | 81.00 KiB/s   Receiving objects:  33% (57747/170190), 34.74 MiB | 76.00 KiB/s   Receiving objects:  34% (57865/170190), 34.74 MiB | 76.00 KiB/s   Receiving objects:  34% (57922/170190), 34.82 MiB | 80.00 KiB/s   Receiving objects:  34% (58003/170190), 34.89 MiB | 75.00 KiB/s   Receiving objects:  34% (58123/170190), 34.96 MiB | 77.00 KiB/s   Receiving objects:  34% (58297/170190), 35.02 MiB | 80.00 KiB/s   Receiving objects:  34% (58466/170190), 35.13 MiB | 80.00 KiB/s   Receiving objects:  34% (58611/170190), 35.18 MiB | 79.00 KiB/s   Receiving objects:  34% (58757/170190), 35.26 MiB | 71.00 KiB/s   Receiving objects:  34% (58800/170190), 35.29 MiB | 64.00 KiB/s   Receiving objects:  34% (59028/170190), 35.33 MiB | 66.00 KiB/s   Receiving objects:  34% (59120/170190), 35.43 MiB | 66.00 KiB/s   Receiving objects:  34% (59326/170190), 35.47 MiB | 63.00 KiB/s   Receiving objects:  34% (59408/170190), 35.57 MiB | 64.00 KiB/s   Receiving objects:  35% (59567/170190), 35.62 MiB | 66.00 KiB/s   Receiving objects:  35% (59615/170190), 35.68 MiB | 70.00 KiB/s   Receiving objects:  35% (59748/170190), 35.74 MiB | 84.00 KiB/s   Receiving objects:  35% (60070/170190), 35.85 MiB | 90.00 KiB/s   Receiving objects:  35% (60402/170190), 35.97 MiB | 98.00 KiB/s   Receiving objects:  35% (60543/170190), 36.08 MiB | 102.00 KiB/s   Receiving objects:  35% (60754/170190), 36.18 MiB | 110.00 KiB/s   Receiving objects:  35% (60868/170190), 36.33 MiB | 121.00 KiB/s   Receiving objects:  35% (61116/170190), 36.46 MiB | 124.00 KiB/s   Receiving objects:  36% (61269/170190), 36.46 MiB | 124.00 KiB/s   Receiving objects:  36% (61496/170190), 36.61 MiB | 129.00 KiB/s   Receiving objects:  36% (61553/170190), 36.69 MiB | 123.00 KiB/s   Receiving objects:  36% (61691/170190), 36.75 MiB | 115.00 KiB/s   Receiving objects:  36% (61847/170190), 36.91 MiB | 111.00 KiB/s   Receiving objects:  36% (61996/170190), 36.98 MiB | 114.00 KiB/s   Receiving objects:  36% (62130/170190), 37.14 MiB | 113.00 KiB/s   Receiving objects:  36% (62265/170190), 37.27 MiB | 116.00 KiB/s   Receiving objects:  36% (62365/170190), 37.38 MiB | 122.00 KiB/s   Receiving objects:  36% (62397/170190), 37.42 MiB | 113.00 KiB/s   Receiving objects:  36% (62529/170190), 37.49 MiB | 98.00 KiB/s   Receiving objects:  36% (62592/170190), 37.55 MiB | 79.00 KiB/s   Receiving objects:  36% (62693/170190), 37.61 MiB | 63.00 KiB/s   Receiving objects:  36% (62814/170190), 37.68 MiB | 59.00 KiB/s   Receiving objects:  36% (62875/170190), 37.73 MiB | 62.00 KiB/s   Receiving objects:  36% (62950/170190), 37.78 MiB | 61.00 KiB/s   Receiving objects:  37% (62971/170190), 37.81 MiB | 61.00 KiB/s   Receiving objects:  37% (63070/170190), 37.85 MiB | 63.00 KiB/s   Receiving objects:  37% (63195/170190), 37.96 MiB | 70.00 KiB/s   Receiving objects:  37% (63527/170190), 38.14 MiB | 97.00 KiB/s   Receiving objects:  37% (63705/170190), 38.21 MiB | 98.00 KiB/s   Receiving objects:  37% (63777/170190), 38.29 MiB | 96.00 KiB/s   Receiving objects:  37% (63875/170190), 38.32 MiB | 95.00 KiB/s   Receiving objects:  37% (64210/170190), 38.41 MiB | 96.00 KiB/s   Receiving objects:  37% (64461/170190), 38.53 MiB | 89.00 KiB/s   Receiving objects:  37% (64645/170190), 38.68 MiB | 89.00 KiB/s   Receiving objects:  38% (64673/170190), 38.68 MiB | 89.00 KiB/s   Receiving objects:  38% (64839/170190), 38.77 MiB | 100.00 KiB/s   Receiving objects:  38% (64952/170190), 38.89 MiB | 115.00 KiB/s   Receiving objects:  38% (65104/170190), 38.96 MiB | 109.00 KiB/s   Receiving objects:  38% (65400/170190), 39.11 MiB | 115.00 KiB/s   Receiving objects:  38% (65569/170190), 39.18 MiB | 115.00 KiB/s   Receiving objects:  38% (65678/170190), 39.27 MiB | 97.00 KiB/s   Receiving objects:  38% (65903/170190), 39.41 MiB | 100.00 KiB/s   Receiving objects:  38% (66274/170190), 39.49 MiB | 109.00 KiB/s   Receiving objects:  39% (66375/170190), 39.56 MiB | 116.00 KiB/s   Receiving objects:  39% (66461/170190), 39.64 MiB | 118.00 KiB/s   Receiving objects:  39% (66561/170190), 39.76 MiB | 109.00 KiB/s   Receiving objects:  39% (66640/170190), 39.82 MiB | 111.00 KiB/s   Receiving objects:  39% (66681/170190), 39.86 MiB | 105.00 KiB/s   Receiving objects:  39% (66748/170190), 39.92 MiB | 91.00 KiB/s   Receiving objects:  39% (66939/170190), 40.00 MiB | 81.00 KiB/s   Receiving objects:  39% (67179/170190), 40.11 MiB | 78.00 KiB/s   Receiving objects:  39% (67768/170190), 40.21 MiB | 78.00 KiB/s   Receiving objects:  39% (67908/170190), 40.37 MiB | 94.00 KiB/s   Receiving objects:  39% (68032/170190), 40.43 MiB | 100.00 KiB/s   Receiving objects:  40% (68076/170190), 40.46 MiB | 99.00 KiB/s   Receiving objects:  40% (68254/170190), 40.50 MiB | 96.00 KiB/s   Receiving objects:  40% (68531/170190), 40.53 MiB | 84.00 KiB/s   Receiving objects:  40% (68727/170190), 40.56 MiB | 79.00 KiB/s   Receiving objects:  40% (69104/170190), 40.68 MiB | 80.00 KiB/s   Receiving objects:  40% (69463/170190), 40.79 MiB | 74.00 KiB/s   Receiving objects:  40% (69658/170190), 40.90 MiB | 78.00 KiB/s   Receiving objects:  41% (69778/170190), 40.90 MiB | 78.00 KiB/s   Receiving objects:  41% (70084/170190), 40.99 MiB | 89.00 KiB/s   Receiving objects:  41% (70313/170190), 41.12 MiB | 99.00 KiB/s   Receiving objects:  41% (70394/170190), 41.18 MiB | 97.00 KiB/s   Receiving objects:  41% (70489/170190), 41.21 MiB | 91.00 KiB/s   Receiving objects:  41% (70580/170190), 41.35 MiB | 92.00 KiB/s   Receiving objects:  41% (70742/170190), 41.39 MiB | 90.00 KiB/s   Receiving objects:  41% (70913/170190), 41.53 MiB | 82.00 KiB/s   Receiving objects:  41% (71076/170190), 41.59 MiB | 88.00 KiB/s   Receiving objects:  41% (71265/170190), 41.75 MiB | 107.00 KiB/s   Receiving objects:  41% (71324/170190), 41.82 MiB | 107.00 KiB/s   Receiving objects:  41% (71399/170190), 41.92 MiB | 97.00 KiB/s   Receiving objects:  41% (71444/170190), 41.98 MiB | 87.00 KiB/s   Receiving objects:  42% (71480/170190), 41.98 MiB | 87.00 KiB/s   Receiving objects:  42% (71515/170190), 42.03 MiB | 84.00 KiB/s   Receiving objects:  42% (71623/170190), 42.12 MiB | 69.00 KiB/s   Receiving objects:  42% (71691/170190), 42.18 MiB | 66.00 KiB/s   Receiving objects:  42% (71741/170190), 42.23 MiB | 67.00 KiB/s   Receiving objects:  42% (71881/170190), 42.34 MiB | 73.00 KiB/s   Receiving objects:  42% (72000/170190), 42.39 MiB | 76.00 KiB/s   Receiving objects:  42% (72143/170190), 42.54 MiB | 83.00 KiB/s   Receiving objects:  42% (72239/170190), 42.65 MiB | 90.00 KiB/s   Receiving objects:  42% (72274/170190), 42.70 MiB | 94.00 KiB/s   Receiving objects:  42% (72300/170190), 42.73 MiB | 88.00 KiB/s   Receiving objects:  42% (72432/170190), 42.85 MiB | 89.00 KiB/s   Receiving objects:  42% (72496/170190), 42.95 MiB | 85.00 KiB/s   Receiving objects:  42% (72581/170190), 43.00 MiB | 80.00 KiB/s   Receiving objects:  42% (72664/170190), 43.09 MiB | 77.00 KiB/s   Receiving objects:  42% (72914/170190), 43.18 MiB | 87.00 KiB/s   Receiving objects:  42% (73006/170190), 43.31 MiB | 102.00 KiB/s   Receiving objects:  42% (73092/170190), 43.42 MiB | 95.00 KiB/s   Receiving objects:  43% (73182/170190), 43.42 MiB | 95.00 KiB/s   Receiving objects:  43% (73277/170190), 43.48 MiB | 97.00 KiB/s   Receiving objects:  43% (73390/170190), 43.60 MiB | 107.00 KiB/s   Receiving objects:  43% (73562/170190), 43.70 MiB | 102.00 KiB/s   Receiving objects:  43% (73691/170190), 43.82 MiB | 100.00 KiB/s   Receiving objects:  43% (73793/170190), 43.89 MiB | 92.00 KiB/s   Receiving objects:  43% (73871/170190), 43.93 MiB | 88.00 KiB/s   Receiving objects:  43% (73990/170190), 44.00 MiB | 73.00 KiB/s   Receiving objects:  43% (74090/170190), 44.03 MiB | 71.00 KiB/s   Receiving objects:  43% (74255/170190), 44.14 MiB | 66.00 KiB/s   Receiving objects:  43% (74416/170190), 44.20 MiB | 66.00 KiB/s   Receiving objects:  43% (74675/170190), 44.29 MiB | 72.00 KiB/s   Receiving objects:  44% (74884/170190), 44.29 MiB | 72.00 KiB/s   Receiving objects:  44% (75497/170190), 44.45 MiB | 87.00 KiB/s   Receiving objects:  44% (76079/170190), 44.51 MiB | 87.00 KiB/s   Receiving objects:  44% (76229/170190), 44.54 MiB | 82.00 KiB/s   Receiving objects:  44% (76353/170190), 44.57 MiB | 77.00 KiB/s   Receiving objects:  45% (76586/170190), 44.65 MiB | 82.00 KiB/s   Receiving objects:  45% (76625/170190), 44.72 MiB | 84.00 KiB/s   Receiving objects:  45% (76736/170190), 44.76 MiB | 82.00 KiB/s   Receiving objects:  45% (77507/170190), 44.89 MiB | 77.00 KiB/s   Receiving objects:  45% (77752/170190), 45.01 MiB | 93.00 KiB/s   Receiving objects:  46% (78288/170190), 45.09 MiB | 107.00 KiB/s   Receiving objects:  46% (78405/170190), 45.17 MiB | 117.00 KiB/s   Receiving objects:  46% (78704/170190), 45.28 MiB | 123.00 KiB/s   Receiving objects:  46% (79263/170190), 45.45 MiB | 140.00 KiB/s   Receiving objects:  46% (79582/170190), 45.57 MiB | 131.00 KiB/s   Receiving objects:  46% (79639/170190), 45.61 MiB | 125.00 KiB/s   Receiving objects:  47% (79990/170190), 45.71 MiB | 118.00 KiB/s   Receiving objects:  47% (80152/170190), 45.71 MiB | 118.00 KiB/s   Receiving objects:  47% (80390/170190), 45.82 MiB | 105.00 KiB/s   Receiving objects:  47% (81140/170190), 45.98 MiB | 101.00 KiB/s   Receiving objects:  48% (81692/170190), 45.98 MiB | 101.00 KiB/s   Receiving objects:  48% (82302/170190), 46.08 MiB | 109.00 KiB/s   Receiving objects:  48% (82486/170190), 46.18 MiB | 112.00 KiB/s   Receiving objects:  48% (82747/170190), 46.21 MiB | 107.00 KiB/s   Receiving objects:  48% (82962/170190), 46.31 MiB | 98.00 KiB/s   Receiving objects:  48% (83003/170190), 46.36 MiB | 95.00 KiB/s   Receiving objects:  48% (83291/170190), 46.48 MiB | 90.00 KiB/s   Receiving objects:  48% (83324/170190), 46.56 MiB | 74.00 KiB/s   Receiving objects:  49% (83394/170190), 46.56 MiB | 74.00 KiB/s   Receiving objects:  49% (83525/170190), 46.67 MiB | 86.00 KiB/s   Receiving objects:  49% (83631/170190), 46.76 MiB | 80.00 KiB/s   Receiving objects:  49% (83735/170190), 46.76 MiB | 80.00 KiB/s   Receiving objects:  49% (84341/170190), 46.86 MiB | 82.00 KiB/s   Receiving objects:  49% (84404/170190), 46.93 MiB | 73.00 KiB/s   Receiving objects:  49% (84772/170190), 47.00 MiB | 79.00 KiB/s   Receiving objects:  49% (85068/170190), 47.12 MiB | 81.00 KiB/s   Receiving objects:  50% (85095/170190), 47.12 MiB | 81.00 KiB/s   Receiving objects:  50% (86070/170190), 47.27 MiB | 97.00 KiB/s   Receiving objects:  50% (86474/170190), 47.31 MiB | 94.00 KiB/s   Receiving objects:  51% (86797/170190), 47.36 MiB | 92.00 KiB/s   Receiving objects:  51% (86823/170190), 47.39 MiB | 91.00 KiB/s   Receiving objects:  51% (87250/170190), 47.52 MiB | 96.00 KiB/s   Receiving objects:  51% (87323/170190), 47.54 MiB | 86.00 KiB/s   Receiving objects:  51% (87672/170190), 47.61 MiB | 75.00 KiB/s   Receiving objects:  51% (87896/170190), 47.64 MiB | 64.00 KiB/s   Receiving objects:  52% (88499/170190), 47.70 MiB | 67.00 KiB/s   Receiving objects:  52% (89155/170190), 47.78 MiB | 74.00 KiB/s   Receiving objects:  52% (90088/170190), 47.84 MiB | 78.00 KiB/s   Receiving objects:  53% (90201/170190), 47.90 MiB | 78.00 KiB/s   Receiving objects:  53% (90304/170190), 47.94 MiB | 76.00 KiB/s   Receiving objects:  53% (90465/170190), 48.03 MiB | 81.00 KiB/s   Receiving objects:  53% (90569/170190), 48.11 MiB | 91.00 KiB/s   Receiving objects:  53% (90736/170190), 48.21 MiB | 101.00 KiB/s   Receiving objects:  53% (90816/170190), 48.37 MiB | 87.00 KiB/s   Receiving objects:  53% (90816/170190), 48.40 MiB | 85.00 KiB/s   Receiving objects:  53% (90816/170190), 48.45 MiB | 88.00 KiB/s   Receiving objects:  53% (90816/170190), 48.56 MiB | 84.00 KiB/s   Receiving objects:  53% (90816/170190), 48.64 MiB | 79.00 KiB/s   Receiving objects:  53% (90816/170190), 48.73 MiB | 71.00 KiB/s   Receiving objects:  53% (90816/170190), 48.78 MiB | 78.00 KiB/s   Receiving objects:  53% (90816/170190), 48.89 MiB | 87.00 KiB/s   Receiving objects:  53% (90816/170190), 49.07 MiB | 101.00 KiB/s   Receiving objects:  53% (90816/170190), 49.25 MiB | 120.00 KiB/s   Receiving objects:  53% (90816/170190), 49.32 MiB | 124.00 KiB/s   Receiving objects:  53% (90816/170190), 49.43 MiB | 129.00 KiB/s   Receiving objects:  53% (90816/170190), 49.54 MiB | 122.00 KiB/s   Receiving objects:  53% (90816/170190), 49.62 MiB | 118.00 KiB/s   Receiving objects:  53% (90816/170190), 49.75 MiB | 110.00 KiB/s   Receiving objects:  53% (90816/170190), 49.82 MiB | 105.00 KiB/s   Receiving objects:  53% (90816/170190), 49.90 MiB | 95.00 KiB/s   Receiving objects:  53% (90816/170190), 50.03 MiB | 99.00 KiB/s   Receiving objects:  53% (90816/170190), 50.12 MiB | 107.00 KiB/s   Receiving objects:  53% (90816/170190), 50.22 MiB | 103.00 KiB/s   Receiving objects:  53% (90817/170190), 50.29 MiB | 96.00 KiB/s   Receiving objects:  53% (90817/170190), 50.36 MiB | 81.00 KiB/s   Receiving objects:  53% (90817/170190), 50.42 MiB | 87.00 KiB/s   Receiving objects:  53% (90817/170190), 50.51 MiB | 84.00 KiB/s   Receiving objects:  53% (90841/170190), 50.57 MiB | 78.00 KiB/s   Receiving objects:  53% (90977/170190), 50.71 MiB | 85.00 KiB/s   Receiving objects:  53% (91022/170190), 50.80 MiB | 89.00 KiB/s   Receiving objects:  53% (91022/170190), 50.88 MiB | 92.00 KiB/s   Receiving objects:  53% (91022/170190), 50.96 MiB | 89.00 KiB/s   Receiving objects:  53% (91022/170190), 51.02 MiB | 90.00 KiB/s   Receiving objects:  53% (91022/170190), 51.07 MiB | 70.00 KiB/s   Receiving objects:  53% (91022/170190), 51.11 MiB | 71.00 KiB/s   Receiving objects:  53% (91022/170190), 51.21 MiB | 69.00 KiB/s   Receiving objects:  53% (91022/170190), 51.29 MiB | 70.00 KiB/s   Receiving objects:  53% (91022/170190), 51.39 MiB | 71.00 KiB/s   Receiving objects:  53% (91022/170190), 51.46 MiB | 81.00 KiB/s   Receiving objects:  53% (91152/170190), 51.52 MiB | 89.00 KiB/s   Receiving objects:  53% (91330/170190), 51.62 MiB | 92.00 KiB/s   Receiving objects:  53% (91590/170190), 51.71 MiB | 89.00 KiB/s   Receiving objects:  53% (91796/170190), 51.82 MiB | 98.00 KiB/s   Receiving objects:  53% (91804/170190), 51.96 MiB | 103.00 KiB/s   Receiving objects:  53% (91804/170190), 52.04 MiB | 88.00 KiB/s   Receiving objects:  53% (91804/170190), 52.16 MiB | 101.00 KiB/s   Receiving objects:  53% (91804/170190), 52.32 MiB | 114.00 KiB/s   Receiving objects:  53% (91804/170190), 52.36 MiB | 106.00 KiB/s   Receiving objects:  53% (91804/170190), 52.47 MiB | 98.00 KiB/s   Receiving objects:  53% (91804/170190), 52.52 MiB | 102.00 KiB/s   Receiving objects:  53% (91804/170190), 52.60 MiB | 93.00 KiB/s   error: index-pack died of signal 15
fatal: index-pack failed

	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl.launchCommandIn(CliGitAPIImpl.java:2042)
	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl.launchCommandWithCredentials(CliGitAPIImpl.java:1761)
	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl.access$400(CliGitAPIImpl.java:72)
	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl$1.execute(CliGitAPIImpl.java:442)
	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl$2.execute(CliGitAPIImpl.java:655)
	at org.jenkinsci.plugins.gitclient.RemoteGitImpl$CommandInvocationHandler$1.call(RemoteGitImpl.java:153)
	at org.jenkinsci.plugins.gitclient.RemoteGitImpl$CommandInvocationHandler$1.call(RemoteGitImpl.java:146)
	at hudson.remoting.UserRequest.perform(UserRequest.java:212)
	at hudson.remoting.UserRequest.perform(UserRequest.java:54)
	at hudson.remoting.Request$2.run(Request.java:369)
	at hudson.remoting.InterceptingExecutorService$1.call(InterceptingExecutorService.java:72)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617)
	at java.lang.Thread.run(Thread.java:748)
	Suppressed: hudson.remoting.Channel$CallSiteStackTrace: Remote call to H32
		at hudson.remoting.Channel.attachCallSiteStackTrace(Channel.java:1741)
		at hudson.remoting.UserRequest$ExceptionResponse.retrieve(UserRequest.java:357)
		at hudson.remoting.Channel.call(Channel.java:955)
		at org.jenkinsci.plugins.gitclient.RemoteGitImpl$CommandInvocationHandler.execute(RemoteGitImpl.java:146)
		at sun.reflect.GeneratedMethodAccessor927.invoke(Unknown Source)
		at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
		at java.lang.reflect.Method.invoke(Method.java:498)
		at org.jenkinsci.plugins.gitclient.RemoteGitImpl$CommandInvocationHandler.invoke(RemoteGitImpl.java:132)
		at com.sun.proxy.$Proxy134.execute(Unknown Source)
		at hudson.plugins.git.GitSCM.retrieveChanges(GitSCM.java:1152)
		at hudson.plugins.git.GitSCM.checkout(GitSCM.java:1192)
		at hudson.scm.SCM.checkout(SCM.java:504)
		at hudson.model.AbstractProject.checkout(AbstractProject.java:1208)
		at hudson.model.AbstractBuild$AbstractBuildExecution.defaultCheckout(AbstractBuild.java:574)
		at jenkins.scm.SCMCheckoutStrategy.checkout(SCMCheckoutStrategy.java:86)
		at hudson.model.AbstractBuild$AbstractBuildExecution.run(AbstractBuild.java:499)
		at hudson.model.Run.execute(Run.java:1810)
		at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
		at hudson.model.ResourceController.execute(ResourceController.java:97)
		at hudson.model.Executor.run(Executor.java:429)
ERROR: Error cloning remote repo 'origin'
Retrying after 10 seconds
No credentials specified
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 16769d263e2e8fd91704d2e3519abf9dcba507df (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 16769d263e2e8fd91704d2e3519abf9dcba507df
Commit message: "KAFKA-8215: Upgrade Rocks to v5.18.3 (#6743)"
 > git rev-list --no-walk a1286edb040a5d368a76d6c9c809c5cf0c080ec8 # timeout=10
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: No tool found matching GRADLE_4_10_2_HOME
[kafka-trunk-jdk11] $ /bin/bash -xe /tmp/jenkins1389855271025184090.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk11/ws/.gradle>
+ /bin/gradle
/tmp/jenkins1389855271025184090.sh: line 4: /bin/gradle: No such file or directory
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
ERROR: No tool found matching GRADLE_4_10_2_HOME
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #538

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

Changes:

[github] MINOR: Fix race condition in Streams tests (#6748)

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on ubuntu-1 (ubuntu trusty) in workspace <https://builds.apache.org/job/kafka-trunk-jdk11/ws/>
[WS-CLEANUP] Deleting project workspace...
[WS-CLEANUP] Deferred wipeout is used...
[WS-CLEANUP] Done
No credentials specified
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-trunk-jdk11/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
ERROR: Timeout after 10 minutes
ERROR: Error cloning remote repo 'origin'
hudson.plugins.git.GitException: Command "git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*" returned status code 128:
stdout: 
stderr: remote: Enumerating objects: 170120, done.        
Receiving objects:   0% (1/170120)   Receiving objects:   0% (874/170120), 372.01 KiB | 331.00 KiB/s   Receiving objects:   0% (1091/170120), 428.01 KiB | 254.00 KiB/s   Receiving objects:   0% (1246/170120), 508.01 KiB | 181.00 KiB/s   Receiving objects:   0% (1453/170120), 596.01 KiB | 152.00 KiB/s   Receiving objects:   1% (1702/170120), 676.01 KiB | 148.00 KiB/s   Receiving objects:   1% (1730/170120), 724.01 KiB | 142.00 KiB/s   Receiving objects:   1% (1980/170120), 796.01 KiB | 104.00 KiB/s   Receiving objects:   1% (2148/170120), 892.01 KiB | 89.00 KiB/s   Receiving objects:   1% (2306/170120), 972.01 KiB | 87.00 KiB/s   Receiving objects:   1% (2530/170120), 1020.01 KiB | 90.00 KiB/s   Receiving objects:   1% (2863/170120), 1.14 MiB | 95.00 KiB/s   Receiving objects:   1% (3191/170120), 1.29 MiB | 101.00 KiB/s   Receiving objects:   2% (3403/170120), 1.35 MiB | 105.00 KiB/s   Receiving objects:   2% (3527/170120), 1.43 MiB | 110.00 KiB/s   Receiving objects:   2% (3757/170120), 1.51 MiB | 113.00 KiB/s   Receiving objects:   2% (3995/170120), 1.56 MiB | 112.00 KiB/s   Receiving objects:   2% (4283/170120), 1.68 MiB | 106.00 KiB/s   Receiving objects:   2% (4537/170120), 1.79 MiB | 102.00 KiB/s   Receiving objects:   2% (4796/170120), 1.89 MiB | 95.00 KiB/s   Receiving objects:   2% (5005/170120), 1.93 MiB | 94.00 KiB/s   Receiving objects:   3% (5104/170120), 1.98 MiB | 94.00 KiB/s   Receiving objects:   3% (5316/170120), 2.04 MiB | 97.00 KiB/s   Receiving objects:   3% (5552/170120), 2.14 MiB | 94.00 KiB/s   Receiving objects:   3% (5841/170120), 2.25 MiB | 92.00 KiB/s   Receiving objects:   3% (6029/170120), 2.29 MiB | 89.00 KiB/s   Receiving objects:   3% (6225/170120), 2.39 MiB | 82.00 KiB/s   Receiving objects:   3% (6418/170120), 2.44 MiB | 81.00 KiB/s   Receiving objects:   3% (6732/170120), 2.56 MiB | 82.00 KiB/s   Receiving objects:   4% (6805/170120), 2.56 MiB | 82.00 KiB/s   Receiving objects:   4% (7066/170120), 2.62 MiB | 83.00 KiB/s   Receiving objects:   4% (7388/170120), 2.74 MiB | 89.00 KiB/s   Receiving objects:   4% (7801/170120), 2.86 MiB | 95.00 KiB/s   Receiving objects:   4% (8151/170120), 2.96 MiB | 99.00 KiB/s   Receiving objects:   4% (8442/170120), 3.00 MiB | 98.00 KiB/s   Receiving objects:   5% (8506/170120), 3.00 MiB | 98.00 KiB/s   Receiving objects:   5% (8829/170120), 3.10 MiB | 92.00 KiB/s   Receiving objects:   5% (9092/170120), 3.21 MiB | 89.00 KiB/s   Receiving objects:   5% (9276/170120), 3.25 MiB | 86.00 KiB/s   Receiving objects:   5% (9359/170120), 3.36 MiB | 84.00 KiB/s   Receiving objects:   5% (9440/170120), 3.44 MiB | 85.00 KiB/s   Receiving objects:   5% (9532/170120), 3.49 MiB | 86.00 KiB/s   Receiving objects:   5% (9578/170120), 3.61 MiB | 87.00 KiB/s   Receiving objects:   5% (9675/170120), 3.76 MiB | 98.00 KiB/s   Receiving objects:   5% (9822/170120), 3.84 MiB | 104.00 KiB/s   Receiving objects:   5% (10043/170120), 3.97 MiB | 115.00 KiB/s   Receiving objects:   5% (10191/170120), 4.11 MiB | 126.00 KiB/s   Receiving objects:   6% (10208/170120), 4.11 MiB | 126.00 KiB/s   Receiving objects:   6% (10317/170120), 4.25 MiB | 132.00 KiB/s   Receiving objects:   6% (10459/170120), 4.40 MiB | 132.00 KiB/s   Receiving objects:   6% (10557/170120), 4.50 MiB | 124.00 KiB/s   Receiving objects:   6% (10730/170120), 4.55 MiB | 120.00 KiB/s   Receiving objects:   6% (10847/170120), 4.66 MiB | 113.00 KiB/s   Receiving objects:   6% (10932/170120), 4.75 MiB | 104.00 KiB/s   Receiving objects:   6% (11149/170120), 4.86 MiB | 97.00 KiB/s   Receiving objects:   6% (11197/170120), 4.98 MiB | 98.00 KiB/s   Receiving objects:   6% (11265/170120), 5.03 MiB | 98.00 KiB/s   Receiving objects:   6% (11348/170120), 5.16 MiB | 100.00 KiB/s   Receiving objects:   6% (11392/170120), 5.24 MiB | 93.00 KiB/s   Receiving objects:   6% (11480/170120), 5.29 MiB | 93.00 KiB/s   Receiving objects:   6% (11608/170120), 5.42 MiB | 92.00 KiB/s   Receiving objects:   6% (11743/170120), 5.54 MiB | 97.00 KiB/s   Receiving objects:   6% (11906/170120), 5.65 MiB | 95.00 KiB/s   Receiving objects:   7% (11909/170120), 5.65 MiB | 95.00 KiB/s   Receiving objects:   7% (12147/170120), 5.79 MiB | 110.00 KiB/s   Receiving objects:   7% (12187/170120), 5.82 MiB | 107.00 KiB/s   Receiving objects:   7% (12234/170120), 5.90 MiB | 96.00 KiB/s   Receiving objects:   7% (12329/170120), 5.97 MiB | 87.00 KiB/s   Receiving objects:   7% (12453/170120), 6.02 MiB | 83.00 KiB/s   Receiving objects:   7% (12533/170120), 6.12 MiB | 75.00 KiB/s   Receiving objects:   7% (12705/170120), 6.28 MiB | 88.00 KiB/s   Receiving objects:   7% (12741/170120), 6.32 MiB | 92.00 KiB/s   Receiving objects:   7% (12858/170120), 6.46 MiB | 98.00 KiB/s   Receiving objects:   7% (12951/170120), 6.61 MiB | 113.00 KiB/s   Receiving objects:   7% (13060/170120), 6.75 MiB | 126.00 KiB/s   Receiving objects:   7% (13115/170120), 6.79 MiB | 115.00 KiB/s   Receiving objects:   7% (13174/170120), 6.90 MiB | 119.00 KiB/s   Receiving objects:   7% (13320/170120), 7.04 MiB | 119.00 KiB/s   Receiving objects:   7% (13388/170120), 7.16 MiB | 111.00 KiB/s   Receiving objects:   7% (13519/170120), 7.21 MiB | 108.00 KiB/s   Receiving objects:   8% (13610/170120), 7.30 MiB | 108.00 KiB/s   Receiving objects:   8% (13662/170120), 7.39 MiB | 119.00 KiB/s   Receiving objects:   8% (13706/170120), 7.48 MiB | 109.00 KiB/s   Receiving objects:   8% (13812/170120), 7.53 MiB | 106.00 KiB/s   Receiving objects:   8% (13859/170120), 7.66 MiB | 106.00 KiB/s   Receiving objects:   8% (13919/170120), 7.73 MiB | 97.00 KiB/s   Receiving objects:   8% (13960/170120), 7.75 MiB | 83.00 KiB/s   Receiving objects:   8% (14133/170120), 7.88 MiB | 84.00 KiB/s   Receiving objects:   8% (14199/170120), 8.03 MiB | 95.00 KiB/s   Receiving objects:   8% (14210/170120), 8.08 MiB | 91.00 KiB/s   Receiving objects:   8% (14211/170120), 8.28 MiB | 107.00 KiB/s   Receiving objects:   8% (14215/170120), 8.39 MiB | 118.00 KiB/s   Receiving objects:   8% (14216/170120), 8.48 MiB | 100.00 KiB/s   Receiving objects:   8% (14219/170120), 8.54 MiB | 101.00 KiB/s   Receiving objects:   8% (14219/170120), 8.64 MiB | 101.00 KiB/s   Receiving objects:   8% (14219/170120), 8.77 MiB | 96.00 KiB/s   Receiving objects:   8% (14220/170120), 8.89 MiB | 102.00 KiB/s   Receiving objects:   8% (14221/170120), 8.96 MiB | 107.00 KiB/s   Receiving objects:   8% (14222/170120), 9.00 MiB | 104.00 KiB/s   Receiving objects:   8% (14222/170120), 9.17 MiB | 105.00 KiB/s   Receiving objects:   8% (14223/170120), 9.29 MiB | 103.00 KiB/s   Receiving objects:   8% (14224/170120), 9.35 MiB | 103.00 KiB/s   Receiving objects:   8% (14226/170120), 9.46 MiB | 97.00 KiB/s   Receiving objects:   8% (14227/170120), 9.54 MiB | 94.00 KiB/s   Receiving objects:   8% (14228/170120), 9.57 MiB | 90.00 KiB/s   Receiving objects:   8% (14228/170120), 9.66 MiB | 84.00 KiB/s   Receiving objects:   8% (14230/170120), 9.71 MiB | 83.00 KiB/s   Receiving objects:   8% (14231/170120), 9.85 MiB | 76.00 KiB/s   Receiving objects:   8% (14233/170120), 9.91 MiB | 79.00 KiB/s   Receiving objects:   8% (14233/170120), 10.04 MiB | 94.00 KiB/s   Receiving objects:   8% (14235/170120), 10.12 MiB | 93.00 KiB/s   Receiving objects:   8% (14236/170120), 10.20 MiB | 85.00 KiB/s   Receiving objects:   8% (14236/170120), 10.22 MiB | 82.00 KiB/s   Receiving objects:   8% (14238/170120), 10.30 MiB | 76.00 KiB/s   Receiving objects:   8% (14239/170120), 10.38 MiB | 66.00 KiB/s   Receiving objects:   8% (14241/170120), 10.43 MiB | 69.00 KiB/s   Receiving objects:   8% (14242/170120), 10.64 MiB | 88.00 KiB/s   Receiving objects:   8% (14243/170120), 10.68 MiB | 91.00 KiB/s   Receiving objects:   8% (14244/170120), 10.75 MiB | 87.00 KiB/s   Receiving objects:   8% (14245/170120), 10.79 MiB | 86.00 KiB/s   Receiving objects:   8% (14247/170120), 10.85 MiB | 90.00 KiB/s   Receiving objects:   8% (14286/170120), 10.93 MiB | 83.00 KiB/s   Receiving objects:   8% (14312/170120), 11.04 MiB | 77.00 KiB/s   Receiving objects:   8% (14360/170120), 11.18 MiB | 91.00 KiB/s   Receiving objects:   8% (14428/170120), 11.25 MiB | 93.00 KiB/s   Receiving objects:   8% (14571/170120), 11.30 MiB | 91.00 KiB/s   Receiving objects:   8% (14719/170120), 11.38 MiB | 92.00 KiB/s   Receiving objects:   8% (14788/170120), 11.49 MiB | 91.00 KiB/s   Receiving objects:   8% (14904/170120), 11.56 MiB | 77.00 KiB/s   Receiving objects:   8% (15105/170120), 11.62 MiB | 80.00 KiB/s   Receiving objects:   8% (15193/170120), 11.71 MiB | 80.00 KiB/s   Receiving objects:   9% (15311/170120), 11.83 MiB | 88.00 KiB/s   Receiving objects:   9% (15320/170120), 11.83 MiB | 88.00 KiB/s   Receiving objects:   9% (15425/170120), 11.93 MiB | 87.00 KiB/s   Receiving objects:   9% (15551/170120), 12.00 MiB | 93.00 KiB/s   Receiving objects:   9% (15591/170120), 12.07 MiB | 85.00 KiB/s   Receiving objects:   9% (15755/170120), 12.18 MiB | 91.00 KiB/s   Receiving objects:   9% (15810/170120), 12.22 MiB | 91.00 KiB/s   Receiving objects:   9% (15899/170120), 12.31 MiB | 83.00 KiB/s   Receiving objects:   9% (16038/170120), 12.42 MiB | 83.00 KiB/s   Receiving objects:   9% (16196/170120), 12.56 MiB | 102.00 KiB/s   Receiving objects:   9% (16330/170120), 12.71 MiB | 107.00 KiB/s   Receiving objects:   9% (16480/170120), 12.86 MiB | 118.00 KiB/s   Receiving objects:   9% (16656/170120), 12.93 MiB | 122.00 KiB/s   Receiving objects:   9% (16845/170120), 13.02 MiB | 118.00 KiB/s   Receiving objects:   9% (16954/170120), 13.06 MiB | 109.00 KiB/s   Receiving objects:  10% (17012/170120), 13.11 MiB | 105.00 KiB/s   Receiving objects:  10% (17130/170120), 13.18 MiB | 105.00 KiB/s   Receiving objects:  10% (17264/170120), 13.29 MiB | 96.00 KiB/s   Receiving objects:  10% (17327/170120), 13.35 MiB | 81.00 KiB/s   Receiving objects:  10% (17374/170120), 13.38 MiB | 76.00 KiB/s   Receiving objects:  10% (17501/170120), 13.44 MiB | 74.00 KiB/s   Receiving objects:  10% (17575/170120), 13.52 MiB | 66.00 KiB/s   Receiving objects:  10% (17666/170120), 13.55 MiB | 59.00 KiB/s   Receiving objects:  10% (17855/170120), 13.65 MiB | 65.00 KiB/s   Receiving objects:  10% (17906/170120), 13.79 MiB | 78.00 KiB/s   Receiving objects:  10% (17967/170120), 13.84 MiB | 83.00 KiB/s   Receiving objects:  10% (18082/170120), 13.94 MiB | 89.00 KiB/s   Receiving objects:  10% (18202/170120), 14.02 MiB | 92.00 KiB/s   Receiving objects:  10% (18368/170120), 14.11 MiB | 88.00 KiB/s   Receiving objects:  10% (18446/170120), 14.16 MiB | 73.00 KiB/s   Receiving objects:  10% (18481/170120), 14.21 MiB | 73.00 KiB/s   Receiving objects:  10% (18566/170120), 14.28 MiB | 64.00 KiB/s   Receiving objects:  11% (18714/170120), 14.32 MiB | 64.00 KiB/s   Receiving objects:  11% (18766/170120), 14.32 MiB | 64.00 KiB/s   Receiving objects:  11% (18855/170120), 14.45 MiB | 74.00 KiB/s   Receiving objects:  11% (18939/170120), 14.55 MiB | 80.00 KiB/s   Receiving objects:  11% (19041/170120), 14.68 MiB | 89.00 KiB/s   Receiving objects:  11% (19147/170120), 14.75 MiB | 98.00 KiB/s   Receiving objects:  11% (19223/170120), 14.85 MiB | 102.00 KiB/s   Receiving objects:  11% (19333/170120), 14.93 MiB | 95.00 KiB/s   Receiving objects:  11% (19448/170120), 15.05 MiB | 99.00 KiB/s   Receiving objects:  11% (19682/170120), 15.08 MiB | 90.00 KiB/s   Receiving objects:  11% (19903/170120), 15.19 MiB | 85.00 KiB/s   Receiving objects:  11% (20091/170120), 15.31 MiB | 90.00 KiB/s   Receiving objects:  11% (20182/170120), 15.35 MiB | 88.00 KiB/s   Receiving objects:  11% (20338/170120), 15.44 MiB | 90.00 KiB/s   Receiving objects:  12% (20415/170120), 15.44 MiB | 90.00 KiB/s   Receiving objects:  12% (20589/170120), 15.54 MiB | 89.00 KiB/s   Receiving objects:  12% (20741/170120), 15.68 MiB | 96.00 KiB/s   Receiving objects:  12% (20827/170120), 15.73 MiB | 92.00 KiB/s   Receiving objects:  12% (21046/170120), 15.86 MiB | 99.00 KiB/s   Receiving objects:  12% (21150/170120), 15.98 MiB | 105.00 KiB/s   Receiving objects:  12% (21236/170120), 16.03 MiB | 105.00 KiB/s   Receiving objects:  12% (21313/170120), 16.14 MiB | 105.00 KiB/s   Receiving objects:  12% (21535/170120), 16.29 MiB | 109.00 KiB/s   Receiving objects:  12% (21688/170120), 16.42 MiB | 113.00 KiB/s   Receiving objects:  12% (21943/170120), 16.57 MiB | 118.00 KiB/s   Receiving objects:  12% (22048/170120), 16.63 MiB | 121.00 KiB/s   Receiving objects:  13% (22116/170120), 16.71 MiB | 126.00 KiB/s   Receiving objects:  13% (22176/170120), 16.77 MiB | 124.00 KiB/s   Receiving objects:  13% (22308/170120), 16.86 MiB | 116.00 KiB/s   Receiving objects:  13% (22425/170120), 17.00 MiB | 116.00 KiB/s   Receiving objects:  13% (22555/170120), 17.07 MiB | 118.00 KiB/s   Receiving objects:  13% (22691/170120), 17.25 MiB | 124.00 KiB/s   Receiving objects:  13% (22791/170120), 17.39 MiB | 117.00 KiB/s   Receiving objects:  13% (22861/170120), 17.43 MiB | 115.00 KiB/s   Receiving objects:  13% (22964/170120), 17.53 MiB | 113.00 KiB/s   Receiving objects:  13% (23116/170120), 17.61 MiB | 100.00 KiB/s   Receiving objects:  13% (23327/170120), 17.66 MiB | 93.00 KiB/s   Receiving objects:  13% (23477/170120), 17.80 MiB | 87.00 KiB/s   Receiving objects:  13% (23601/170120), 17.93 MiB | 100.00 KiB/s   Receiving objects:  13% (23705/170120), 17.99 MiB | 91.00 KiB/s   Receiving objects:  13% (23736/170120), 18.01 MiB | 86.00 KiB/s   Receiving objects:  14% (23817/170120), 18.04 MiB | 81.00 KiB/s   Receiving objects:  14% (23852/170120), 18.09 MiB | 80.00 KiB/s   Receiving objects:  14% (23954/170120), 18.11 MiB | 70.00 KiB/s   Receiving objects:  14% (24095/170120), 18.23 MiB | 67.00 KiB/s   Receiving objects:  14% (24213/170120), 18.31 MiB | 62.00 KiB/s   Receiving objects:  14% (24265/170120), 18.35 MiB | 65.00 KiB/s   Receiving objects:  14% (24347/170120), 18.45 MiB | 79.00 KiB/s   Receiving objects:  14% (24534/170120), 18.61 MiB | 99.00 KiB/s   Receiving objects:  14% (24664/170120), 18.71 MiB | 94.00 KiB/s   Receiving objects:  14% (24729/170120), 18.74 MiB | 93.00 KiB/s   Receiving objects:  14% (24893/170120), 18.86 MiB | 104.00 KiB/s   Receiving objects:  14% (25016/170120), 18.99 MiB | 106.00 KiB/s   Receiving objects:  14% (25147/170120), 19.08 MiB | 93.00 KiB/s   Receiving objects:  14% (25302/170120), 19.13 MiB | 92.00 KiB/s   Receiving objects:  14% (25445/170120), 19.24 MiB | 102.00 KiB/s   Receiving objects:  15% (25518/170120), 19.29 MiB | 103.00 KiB/s   Receiving objects:  15% (25561/170120), 19.33 MiB | 94.00 KiB/s   Receiving objects:  15% (25654/170120), 19.41 MiB | 85.00 KiB/s   Receiving objects:  15% (25814/170120), 19.46 MiB | 84.00 KiB/s   Receiving objects:  15% (25856/170120), 19.56 MiB | 82.00 KiB/s   Receiving objects:  15% (25949/170120), 19.65 MiB | 76.00 KiB/s   Receiving objects:  15% (26054/170120), 19.70 MiB | 74.00 KiB/s   Receiving objects:  15% (26337/170120), 19.84 MiB | 87.00 KiB/s   Receiving objects:  15% (26440/170120), 19.94 MiB | 94.00 KiB/s   Receiving objects:  15% (26496/170120), 20.01 MiB | 89.00 KiB/s   Receiving objects:  15% (26549/170120), 20.07 MiB | 92.00 KiB/s   Receiving objects:  15% (26711/170120), 20.17 MiB | 94.00 KiB/s   Receiving objects:  15% (26808/170120), 20.25 MiB | 82.00 KiB/s   Receiving objects:  15% (26989/170120), 20.39 MiB | 87.00 KiB/s   Receiving objects:  15% (27216/170120), 20.48 MiB | 102.00 KiB/s   Receiving objects:  16% (27220/170120), 20.48 MiB | 102.00 KiB/s   Receiving objects:  16% (27342/170120), 20.57 MiB | 103.00 KiB/s   Receiving objects:  16% (27474/170120), 20.64 MiB | 93.00 KiB/s   Receiving objects:  16% (27587/170120), 20.68 MiB | 89.00 KiB/s   Receiving objects:  16% (27689/170120), 20.75 MiB | 82.00 KiB/s   Receiving objects:  16% (28033/170120), 20.79 MiB | 73.00 KiB/s   Receiving objects:  16% (28300/170120), 20.86 MiB | 58.00 KiB/s   Receiving objects:  16% (28404/170120), 20.89 MiB | 56.00 KiB/s   Receiving objects:  16% (28613/170120), 20.95 MiB | 54.00 KiB/s   Receiving objects:  16% (28784/170120), 21.00 MiB | 50.00 KiB/s   Receiving objects:  17% (28921/170120), 21.00 MiB | 50.00 KiB/s   Receiving objects:  17% (29130/170120), 21.07 MiB | 52.00 KiB/s   Receiving objects:  17% (29555/170120), 21.11 MiB | 54.00 KiB/s   Receiving objects:  17% (29841/170120), 21.21 MiB | 59.00 KiB/s   Receiving objects:  17% (30186/170120), 21.25 MiB | 63.00 KiB/s   Receiving objects:  17% (30468/170120), 21.34 MiB | 68.00 KiB/s   Receiving objects:  17% (30619/170120), 21.46 MiB | 78.00 KiB/s   Receiving objects:  18% (30622/170120), 21.46 MiB | 78.00 KiB/s   Receiving objects:  18% (30810/170120), 21.50 MiB | 80.00 KiB/s   Receiving objects:  18% (31002/170120), 21.61 MiB | 83.00 KiB/s   Receiving objects:  18% (31260/170120), 21.68 MiB | 80.00 KiB/s   Receiving objects:  18% (31608/170120), 21.79 MiB | 86.00 KiB/s   Receiving objects:  18% (31875/170120), 21.84 MiB | 85.00 KiB/s   Receiving objects:  18% (32090/170120), 21.93 MiB | 85.00 KiB/s   Receiving objects:  18% (32196/170120), 22.01 MiB | 76.00 KiB/s   Receiving objects:  19% (32323/170120), 22.01 MiB | 76.00 KiB/s   Receiving objects:  19% (32448/170120), 22.11 MiB | 85.00 KiB/s   Receiving objects:  19% (32690/170120), 22.17 MiB | 85.00 KiB/s   Receiving objects:  19% (33300/170120), 22.29 MiB | 88.00 KiB/s   Receiving objects:  19% (33426/170120), 22.41 MiB | 94.00 KiB/s   Receiving objects:  19% (33697/170120), 22.56 MiB | 111.00 KiB/s   Receiving objects:  19% (33985/170120), 22.66 MiB | 113.00 KiB/s   Receiving objects:  20% (34024/170120), 22.66 MiB | 113.00 KiB/s   Receiving objects:  20% (34158/170120), 22.71 MiB | 111.00 KiB/s   Receiving objects:  20% (34260/170120), 22.81 MiB | 102.00 KiB/s   Receiving objects:  20% (34337/170120), 22.85 MiB | 98.00 KiB/s   Receiving objects:  20% (34467/170120), 22.93 MiB | 83.00 KiB/s   Receiving objects:  20% (34597/170120), 23.03 MiB | 80.00 KiB/s   Receiving objects:  20% (34796/170120), 23.13 MiB | 80.00 KiB/s   Receiving objects:  20% (35003/170120), 23.18 MiB | 82.00 KiB/s   Receiving objects:  20% (35348/170120), 23.29 MiB | 91.00 KiB/s   Receiving objects:  20% (35714/170120), 23.44 MiB | 105.00 KiB/s   Receiving objects:  21% (35726/170120), 23.44 MiB | 105.00 KiB/s   Receiving objects:  21% (35995/170120), 23.57 MiB | 110.00 KiB/s   Receiving objects:  21% (36352/170120), 23.67 MiB | 108.00 KiB/s   Receiving objects:  21% (36770/170120), 23.74 MiB | 112.00 KiB/s   Receiving objects:  21% (36948/170120), 23.90 MiB | 121.00 KiB/s   Receiving objects:  21% (37179/170120), 24.05 MiB | 122.00 KiB/s   Receiving objects:  21% (37268/170120), 24.14 MiB | 114.00 KiB/s   Receiving objects:  21% (37377/170120), 24.18 MiB | 115.00 KiB/s   Receiving objects:  22% (37427/170120), 24.22 MiB | 111.00 KiB/s   Receiving objects:  22% (37542/170120), 24.29 MiB | 91.00 KiB/s   Receiving objects:  22% (37613/170120), 24.35 MiB | 88.00 KiB/s   Receiving objects:  22% (37846/170120), 24.45 MiB | 79.00 KiB/s   Receiving objects:  22% (37875/170120), 24.46 MiB | 74.00 KiB/s   Receiving objects:  22% (37975/170120), 24.54 MiB | 72.00 KiB/s   Receiving objects:  22% (38086/170120), 24.64 MiB | 73.00 KiB/s   Receiving objects:  22% (38213/170120), 24.72 MiB | 74.00 KiB/s   Receiving objects:  22% (38318/170120), 24.77 MiB | 73.00 KiB/s   Receiving objects:  22% (38529/170120), 24.89 MiB | 82.00 KiB/s   Receiving objects:  22% (38589/170120), 24.98 MiB | 84.00 KiB/s   Receiving objects:  22% (38710/170120), 25.04 MiB | 84.00 KiB/s   Receiving objects:  22% (38779/170120), 25.12 MiB | 88.00 KiB/s   Receiving objects:  22% (38866/170120), 25.19 MiB | 83.00 KiB/s   Receiving objects:  22% (38976/170120), 25.29 MiB | 79.00 KiB/s   Receiving objects:  23% (39128/170120), 25.34 MiB | 82.00 KiB/s   Receiving objects:  23% (39161/170120), 25.37 MiB | 79.00 KiB/s   Receiving objects:  23% (39275/170120), 25.41 MiB | 76.00 KiB/s   Receiving objects:  23% (39414/170120), 25.47 MiB | 71.00 KiB/s   Receiving objects:  23% (39572/170120), 25.61 MiB | 84.00 KiB/s   Receiving objects:  23% (39694/170120), 25.71 MiB | 86.00 KiB/s   Receiving objects:  23% (39854/170120), 25.82 MiB | 90.00 KiB/s   Receiving objects:  23% (40031/170120), 25.97 MiB | 106.00 KiB/s   Receiving objects:  23% (40131/170120), 26.01 MiB | 109.00 KiB/s   Receiving objects:  23% (40211/170120), 26.10 MiB | 99.00 KiB/s   Receiving objects:  23% (40385/170120), 26.21 MiB | 103.00 KiB/s   Receiving objects:  23% (40628/170120), 26.29 MiB | 109.00 KiB/s   Receiving objects:  23% (40774/170120), 26.38 MiB | 94.00 KiB/s   Receiving objects:  24% (40829/170120), 26.38 MiB | 94.00 KiB/s   Receiving objects:  24% (40898/170120), 26.47 MiB | 89.00 KiB/s   Receiving objects:  24% (40943/170120), 26.50 MiB | 86.00 KiB/s   Receiving objects:  24% (41112/170120), 26.57 MiB | 79.00 KiB/s   Receiving objects:  24% (41261/170120), 26.70 MiB | 80.00 KiB/s   Receiving objects:  24% (41402/170120), 26.82 MiB | 86.00 KiB/s   Receiving objects:  24% (41555/170120), 26.91 MiB | 90.00 KiB/s   Receiving objects:  24% (41778/170120), 27.00 MiB | 101.00 KiB/s   Receiving objects:  24% (41933/170120), 27.11 MiB | 98.00 KiB/s   Receiving objects:  24% (42131/170120), 27.17 MiB | 97.00 KiB/s   Receiving objects:  24% (42327/170120), 27.26 MiB | 92.00 KiB/s   Receiving objects:  24% (42506/170120), 27.37 MiB | 91.00 KiB/s   Receiving objects:  25% (42530/170120), 27.37 MiB | 91.00 KiB/s   Receiving objects:  25% (42669/170120), 27.40 MiB | 88.00 KiB/s   Receiving objects:  25% (42907/170120), 27.49 MiB | 84.00 KiB/s   Receiving objects:  25% (43224/170120), 27.59 MiB | 80.00 KiB/s   Receiving objects:  25% (43776/170120), 27.65 MiB | 83.00 KiB/s   Receiving objects:  25% (44215/170120), 27.76 MiB | 81.00 KiB/s   Receiving objects:  26% (44232/170120), 27.76 MiB | 81.00 KiB/s   Receiving objects:  26% (44542/170120), 27.86 MiB | 87.00 KiB/s   Receiving objects:  26% (44873/170120), 27.96 MiB | 90.00 KiB/s   Receiving objects:  26% (45202/170120), 28.04 MiB | 98.00 KiB/s   Receiving objects:  26% (45411/170120), 28.14 MiB | 96.00 KiB/s   Receiving objects:  26% (45714/170120), 28.22 MiB | 93.00 KiB/s   Receiving objects:  27% (45933/170120), 28.28 MiB | 94.00 KiB/s   Receiving objects:  27% (45989/170120), 28.28 MiB | 94.00 KiB/s   Receiving objects:  27% (46238/170120), 28.34 MiB | 85.00 KiB/s   Receiving objects:  27% (46432/170120), 28.43 MiB | 79.00 KiB/s   Receiving objects:  27% (46577/170120), 28.55 MiB | 83.00 KiB/s   Receiving objects:  27% (46773/170120), 28.67 MiB | 90.00 KiB/s   Receiving objects:  27% (46939/170120), 28.72 MiB | 90.00 KiB/s   Receiving objects:  27% (47045/170120), 28.86 MiB | 105.00 KiB/s   Receiving objects:  27% (47174/170120), 28.98 MiB | 114.00 KiB/s   Receiving objects:  27% (47321/170120), 29.10 MiB | 113.00 KiB/s   Receiving objects:  27% (47423/170120), 29.20 MiB | 108.00 KiB/s   Receiving objects:  27% (47578/170120), 29.24 MiB | 98.00 KiB/s   Receiving objects:  27% (47633/170120), 29.32 MiB | 86.00 KiB/s   Receiving objects:  28% (47634/170120), 29.32 MiB | 86.00 KiB/s   Receiving objects:  28% (47707/170120), 29.36 MiB | 76.00 KiB/s   Receiving objects:  28% (47937/170120), 29.46 MiB | 75.00 KiB/s   Receiving objects:  28% (48040/170120), 29.57 MiB | 78.00 KiB/s   Receiving objects:  28% (48187/170120), 29.61 MiB | 74.00 KiB/s   Receiving objects:  28% (48283/170120), 29.68 MiB | 75.00 KiB/s   Receiving objects:  28% (48326/170120), 29.73 MiB | 71.00 KiB/s   Receiving objects:  28% (48514/170120), 29.76 MiB | 68.00 KiB/s   Receiving objects:  28% (48673/170120), 29.88 MiB | 69.00 KiB/s   Receiving objects:  28% (48765/170120), 29.98 MiB | 71.00 KiB/s   Receiving objects:  28% (48963/170120), 30.04 MiB | 75.00 KiB/s   Receiving objects:  28% (49182/170120), 30.14 MiB | 85.00 KiB/s   Receiving objects:  28% (49260/170120), 30.23 MiB | 95.00 KiB/s   Receiving objects:  29% (49335/170120), 30.23 MiB | 95.00 KiB/s   Receiving objects:  29% (49431/170120), 30.31 MiB | 85.00 KiB/s   Receiving objects:  29% (49593/170120), 30.34 MiB | 78.00 KiB/s   Receiving objects:  29% (49762/170120), 30.40 MiB | 70.00 KiB/s   Receiving objects:  29% (50141/170120), 30.54 MiB | 74.00 KiB/s   Receiving objects:  29% (50314/170120), 30.57 MiB | 71.00 KiB/s   Receiving objects:  29% (50451/170120), 30.65 MiB | 72.00 KiB/s   Receiving objects:  29% (50554/170120), 30.72 MiB | 75.00 KiB/s   Receiving objects:  29% (50689/170120), 30.77 MiB | 69.00 KiB/s   Receiving objects:  29% (50694/170120), 30.79 MiB | 62.00 KiB/s   Receiving objects:  29% (50849/170120), 30.89 MiB | 60.00 KiB/s   Receiving objects:  29% (50977/170120), 30.94 MiB | 61.00 KiB/s   Receiving objects:  30% (51036/170120), 30.99 MiB | 63.00 KiB/s   Receiving objects:  30% (51095/170120), 31.05 MiB | 68.00 KiB/s   Receiving objects:  30% (51269/170120), 31.18 MiB | 82.00 KiB/s   Receiving objects:  30% (51401/170120), 31.31 MiB | 104.00 KiB/s   Receiving objects:  30% (51492/170120), 31.38 MiB | 97.00 KiB/s   Receiving objects:  30% (51626/170120), 31.41 MiB | 91.00 KiB/s   Receiving objects:  30% (51767/170120), 31.52 MiB | 93.00 KiB/s   Receiving objects:  30% (51942/170120), 31.58 MiB | 90.00 KiB/s   Receiving objects:  30% (52189/170120), 31.69 MiB | 87.00 KiB/s   Receiving objects:  30% (52388/170120), 31.79 MiB | 85.00 KiB/s   Receiving objects:  30% (52552/170120), 31.91 MiB | 98.00 KiB/s   Receiving objects:  30% (52676/170120), 31.96 MiB | 98.00 KiB/s   Receiving objects:  31% (52738/170120), 32.00 MiB | 92.00 KiB/s   Receiving objects:  31% (52834/170120), 32.04 MiB | 90.00 KiB/s   Receiving objects:  31% (53026/170120), 32.19 MiB | 102.00 KiB/s   Receiving objects:  31% (53205/170120), 32.29 MiB | 101.00 KiB/s   Receiving objects:  31% (53257/170120), 32.36 MiB | 88.00 KiB/s   Receiving objects:  31% (53469/170120), 32.40 MiB | 88.00 KiB/s   Receiving objects:  31% (53564/170120), 32.49 MiB | 87.00 KiB/s   Receiving objects:  31% (53850/170120), 32.54 MiB | 82.00 KiB/s   Receiving objects:  31% (54023/170120), 32.65 MiB | 78.00 KiB/s   Receiving objects:  31% (54121/170120), 32.74 MiB | 77.00 KiB/s   Receiving objects:  31% (54187/170120), 32.82 MiB | 78.00 KiB/s   Receiving objects:  31% (54383/170120), 32.88 MiB | 83.00 KiB/s   Receiving objects:  32% (54439/170120), 32.88 MiB | 83.00 KiB/s   Receiving objects:  32% (54596/170120), 33.04 MiB | 99.00 KiB/s   Receiving objects:  32% (54998/170120), 33.17 MiB | 101.00 KiB/s   Receiving objects:  32% (55065/170120), 33.22 MiB | 93.00 KiB/s   Receiving objects:  32% (55185/170120), 33.25 MiB | 95.00 KiB/s   Receiving objects:  32% (55381/170120), 33.31 MiB | 83.00 KiB/s   Receiving objects:  32% (55534/170120), 33.36 MiB | 62.00 KiB/s   Receiving objects:  32% (55963/170120), 33.43 MiB | 60.00 KiB/s   Receiving objects:  33% (56140/170120), 33.52 MiB | 68.00 KiB/s   Receiving objects:  33% (56323/170120), 33.59 MiB | 75.00 KiB/s   Receiving objects:  33% (56449/170120), 33.75 MiB | 100.00 KiB/s   Receiving objects:  33% (56705/170120), 33.92 MiB | 127.00 KiB/s   Receiving objects:  33% (56813/170120), 34.03 MiB | 137.00 KiB/s   Receiving objects:  33% (56952/170120), 34.08 MiB | 136.00 KiB/s   Receiving objects:  33% (57152/170120), 34.21 MiB | 129.00 KiB/s   Receiving objects:  33% (57436/170120), 34.38 MiB | 132.00 KiB/s   Receiving objects:  33% (57590/170120), 34.58 MiB | 136.00 KiB/s   Receiving objects:  33% (57752/170120), 34.76 MiB | 150.00 KiB/s   Receiving objects:  34% (57841/170120), 34.76 MiB | 150.00 KiB/s   Receiving objects:  34% (58089/170120), 34.86 MiB | 155.00 KiB/s   Receiving objects:  34% (58296/170120), 35.02 MiB | 162.00 KiB/s   Receiving objects:  34% (58467/170120), 35.12 MiB | 145.00 KiB/s   Receiving objects:  34% (58531/170120), 35.18 MiB | 114.00 KiB/s   Receiving objects:  34% (58758/170120), 35.22 MiB | 108.00 KiB/s   Receiving objects:  34% (58943/170120), 35.30 MiB | 88.00 KiB/s   Receiving objects:  34% (59161/170120), 35.41 MiB | 78.00 KiB/s   Receiving objects:  34% (59346/170120), 35.54 MiB | 83.00 KiB/s   Receiving objects:  34% (59517/170120), 35.58 MiB | 89.00 KiB/s   Receiving objects:  35% (59542/170120), 35.64 MiB | 95.00 KiB/s   Receiving objects:  35% (59842/170120), 35.73 MiB | 103.00 KiB/s   Receiving objects:  35% (60140/170120), 35.90 MiB | 121.00 KiB/s   Receiving objects:  35% (60396/170120), 35.96 MiB | 111.00 KiB/s   Receiving objects:  35% (60489/170120), 36.00 MiB | 102.00 KiB/s   Receiving objects:  35% (60611/170120), 36.11 MiB | 104.00 KiB/s   Receiving objects:  35% (60660/170120), 36.18 MiB | 86.00 KiB/s   Receiving objects:  35% (60716/170120), 36.21 MiB | 72.00 KiB/s   Receiving objects:  35% (60792/170120), 36.29 MiB | 66.00 KiB/s   Receiving objects:  35% (60918/170120), 36.40 MiB | 75.00 KiB/s   Receiving objects:  35% (61198/170120), 36.46 MiB | 78.00 KiB/s   Receiving objects:  36% (61244/170120), 36.51 MiB | 77.00 KiB/s   Receiving objects:  36% (61516/170120), 36.63 MiB | 89.00 KiB/s   Receiving objects:  36% (61568/170120), 36.68 MiB | 95.00 KiB/s   Receiving objects:  36% (61690/170120), 36.80 MiB | 101.00 KiB/s   Receiving objects:  36% (61830/170120), 36.86 MiB | 101.00 KiB/s   Receiving objects:  36% (61916/170120), 36.95 MiB | 92.00 KiB/s   Receiving objects:  36% (61960/170120), 36.99 MiB | 87.00 KiB/s   Receiving objects:  36% (62025/170120), 37.06 MiB | 75.00 KiB/s   Receiving objects:  36% (62129/170120), 37.18 MiB | 78.00 KiB/s   Receiving objects:  36% (62330/170120), 37.26 MiB | 84.00 KiB/s   Receiving objects:  36% (62471/170120), 37.43 MiB | 99.00 KiB/s   Receiving objects:  36% (62607/170120), 37.54 MiB | 110.00 KiB/s   Receiving objects:  36% (62730/170120), 37.62 MiB | 113.00 KiB/s   Receiving objects:  36% (62851/170120), 37.72 MiB | 110.00 KiB/s   Receiving objects:  37% (62945/170120), 37.77 MiB | 103.00 KiB/s   Receiving objects:  37% (62961/170120), 37.77 MiB | 103.00 KiB/s   Receiving objects:  37% (63119/170120), 37.87 MiB | 89.00 KiB/s   Receiving objects:  37% (63208/170120), 37.97 MiB | 86.00 KiB/s   Receiving objects:  37% (63322/170120), 38.06 MiB | 87.00 KiB/s   Receiving objects:  37% (63489/170120), 38.11 MiB | 88.00 KiB/s   Receiving objects:  37% (63690/170120), 38.21 MiB | 86.00 KiB/s   Receiving objects:  37% (63760/170120), 38.29 MiB | 79.00 KiB/s   Receiving objects:  37% (63839/170120), 38.32 MiB | 73.00 KiB/s   Receiving objects:  37% (64021/170120), 38.40 MiB | 68.00 KiB/s   Receiving objects:  37% (64461/170120), 38.46 MiB | 76.00 KiB/s   Receiving objects:  38% (64646/170120), 38.64 MiB | 91.00 KiB/s   Receiving objects:  38% (64685/170120), 38.64 MiB | 91.00 KiB/s   Receiving objects:  38% (64849/170120), 38.82 MiB | 109.00 KiB/s   Receiving objects:  38% (64936/170120), 38.89 MiB | 111.00 KiB/s   Receiving objects:  38% (65143/170120), 38.93 MiB | 112.00 KiB/s   Receiving objects:  38% (65401/170120), 39.08 MiB | 122.00 KiB/s   Receiving objects:  38% (65674/170120), 39.24 MiB | 118.00 KiB/s   Receiving objects:  38% (65792/170120), 39.37 MiB | 106.00 KiB/s   Receiving objects:  38% (66170/170120), 39.44 MiB | 112.00 KiB/s   Receiving objects:  38% (66308/170120), 39.56 MiB | 124.00 KiB/s   Receiving objects:  39% (66347/170120), 39.61 MiB | 118.00 KiB/s   Receiving objects:  39% (66447/170120), 39.65 MiB | 113.00 KiB/s   Receiving objects:  39% (66538/170120), 39.72 MiB | 95.00 KiB/s   Receiving objects:  39% (66665/170120), 39.79 MiB | 94.00 KiB/s   Receiving objects:  39% (66809/170120), 39.94 MiB | 99.00 KiB/s   Receiving objects:  39% (66958/170120), 40.04 MiB | 96.00 KiB/s   Receiving objects:  39% (67639/170120), 40.18 MiB | 107.00 KiB/s   Receiving objects:  39% (67796/170120), 40.26 MiB | 110.00 KiB/s   Receiving objects:  39% (67906/170120), 40.34 MiB | 96.00 KiB/s   Receiving objects:  39% (67997/170120), 40.39 MiB | 93.00 KiB/s   Receiving objects:  40% (68048/170120), 40.44 MiB | 93.00 KiB/s   Receiving objects:  40% (68255/170120), 40.49 MiB | 90.00 KiB/s   Receiving objects:  40% (68726/170120), 40.59 MiB | 81.00 KiB/s   Receiving objects:  40% (68946/170120), 40.64 MiB | 81.00 KiB/s   Receiving objects:  40% (69288/170120), 40.74 MiB | 85.00 KiB/s   Receiving objects:  40% (69567/170120), 40.83 MiB | 85.00 KiB/s   Receiving objects:  40% (69659/170120), 40.87 MiB | 84.00 KiB/s   Receiving objects:  41% (69750/170120), 40.92 MiB | 84.00 KiB/s   Receiving objects:  41% (69890/170120), 40.96 MiB | 85.00 KiB/s   Receiving objects:  41% (70078/170120), 41.03 MiB | 75.00 KiB/s   Receiving objects:  41% (70317/170120), 41.13 MiB | 75.00 KiB/s   Receiving objects:  41% (70481/170120), 41.20 MiB | 79.00 KiB/s   Receiving objects:  41% (70546/170120), 41.29 MiB | 82.00 KiB/s   Receiving objects:  41% (70638/170120), 41.38 MiB | 83.00 KiB/s   Receiving objects:  41% (70770/170120), 41.46 MiB | 86.00 KiB/s   Receiving objects:  41% (70935/170120), 41.55 MiB | 86.00 KiB/s   Receiving objects:  41% (71056/170120), 41.61 MiB | 84.00 KiB/s   Receiving objects:  41% (71100/170120), 41.70 MiB | 79.00 KiB/s   Receiving objects:  41% (71242/170120), 41.75 MiB | 79.00 KiB/s   Receiving objects:  41% (71324/170120), 41.84 MiB | 80.00 KiB/s   Receiving objects:  41% (71421/170120), 41.95 MiB | 85.00 KiB/s   Receiving objects:  42% (71451/170120), 41.95 MiB | 85.00 KiB/s   Receiving objects:  42% (71622/170120), 42.13 MiB | 97.00 KiB/s   Receiving objects:  42% (71765/170120), 42.22 MiB | 107.00 KiB/s   Receiving objects:  42% (71805/170120), 42.29 MiB | 99.00 KiB/s   Receiving objects:  42% (71851/170120), 42.29 MiB | 91.00 KiB/s   Receiving objects:  42% (71931/170120), 42.38 MiB | 90.00 KiB/s   Receiving objects:  42% (72025/170120), 42.43 MiB | 87.00 KiB/s   Receiving objects:  42% (72144/170120), 42.51 MiB | 69.00 KiB/s   Receiving objects:  42% (72195/170120), 42.59 MiB | 64.00 KiB/s   Receiving objects:  42% (72252/170120), 42.68 MiB | 76.00 KiB/s   Receiving objects:  42% (72364/170120), 42.75 MiB | 81.00 KiB/s   Receiving objects:  42% (72472/170120), 42.87 MiB | 88.00 KiB/s   Receiving objects:  42% (72581/170120), 42.99 MiB | 94.00 KiB/s   Receiving objects:  42% (72642/170120), 43.09 MiB | 96.00 KiB/s   Receiving objects:  42% (72770/170120), 43.14 MiB | 98.00 KiB/s   Receiving objects:  42% (72953/170120), 43.25 MiB | 99.00 KiB/s   Receiving objects:  42% (72993/170120), 43.33 MiB | 85.00 KiB/s   Receiving objects:  42% (73063/170120), 43.36 MiB | 76.00 KiB/s   Receiving objects:  43% (73152/170120), 43.40 MiB | 78.00 KiB/s   Receiving objects:  43% (73211/170120), 43.46 MiB | 81.00 KiB/s   Receiving objects:  43% (73331/170120), 43.59 MiB | 86.00 KiB/s   Receiving objects:  43% (73470/170120), 43.64 MiB | 85.00 KiB/s   Receiving objects:  43% (73562/170120), 43.71 MiB | 76.00 KiB/s   Receiving objects:  43% (73646/170120), 43.79 MiB | 84.00 KiB/s   Receiving objects:  43% (73753/170120), 43.87 MiB | 81.00 KiB/s   Receiving objects:  43% (73854/170120), 43.93 MiB | 68.00 KiB/s   Receiving objects:  43% (73944/170120), 43.96 MiB | 62.00 KiB/s   Receiving objects:  43% (74065/170120), 44.03 MiB | 60.00 KiB/s   Receiving objects:  43% (74146/170120), 44.05 MiB | 60.00 KiB/s   Receiving objects:  43% (74366/170120), 44.16 MiB | 64.00 KiB/s   Receiving objects:  43% (74463/170120), 44.25 MiB | 63.00 KiB/s   Receiving objects:  44% (74853/170120), 44.32 MiB | 72.00 KiB/s   Receiving objects:  44% (75254/170120), 44.32 MiB | 72.00 KiB/s   Receiving objects:  44% (76051/170120), 44.47 MiB | 92.00 KiB/s   Receiving objects:  44% (76477/170120), 44.61 MiB | 109.00 KiB/s   Receiving objects:  45% (76554/170120), 44.61 MiB | 109.00 KiB/s   Receiving objects:  45% (76677/170120), 44.74 MiB | 114.00 KiB/s   Receiving objects:  45% (76756/170120), 44.81 MiB | 109.00 KiB/s   Receiving objects:  45% (77055/170120), 44.85 MiB | 104.00 KiB/s   Receiving objects:  45% (77742/170120), 44.98 MiB | 101.00 KiB/s   Receiving objects:  45% (77845/170120), 45.08 MiB | 93.00 KiB/s   Receiving objects:  46% (78256/170120), 45.13 MiB | 88.00 KiB/s   Receiving objects:  46% (78385/170120), 45.15 MiB | 80.00 KiB/s   Receiving objects:  46% (78451/170120), 45.18 MiB | 79.00 KiB/s   Receiving objects:  46% (78608/170120), 45.29 MiB | 87.00 KiB/s   Receiving objects:  46% (78808/170120), 45.42 MiB | 85.00 KiB/s   Receiving objects:  46% (79359/170120), 45.47 MiB | 86.00 KiB/s   Receiving objects:  46% (79725/170120), 45.61 MiB | 93.00 KiB/s   Receiving objects:  46% (79866/170120), 45.70 MiB | 99.00 KiB/s   Receiving objects:  47% (79957/170120), 45.70 MiB | 99.00 KiB/s   Receiving objects:  47% (80306/170120), 45.73 MiB | 92.00 KiB/s   Receiving objects:  47% (80386/170120), 45.82 MiB | 88.00 KiB/s   Receiving objects:  47% (80449/170120), 45.86 MiB | 81.00 KiB/s   Receiving objects:  47% (81274/170120), 45.98 MiB | 82.00 KiB/s   Receiving objects:  48% (81658/170120), 46.04 MiB | 77.00 KiB/s   Receiving objects:  48% (82083/170120), 46.09 MiB | 79.00 KiB/s   Receiving objects:  48% (82594/170120), 46.14 MiB | 81.00 KiB/s   Receiving objects:  48% (82962/170120), 46.28 MiB | 94.00 KiB/s   Receiving objects:  48% (83011/170120), 46.39 MiB | 102.00 KiB/s   Receiving objects:  48% (83293/170120), 46.49 MiB | 99.00 KiB/s   Receiving objects:  49% (83359/170120), 46.55 MiB | 104.00 KiB/s   Receiving objects:  49% (83426/170120), 46.61 MiB | 105.00 KiB/s   Receiving objects:  49% (83510/170120), 46.64 MiB | 94.00 KiB/s   Receiving objects:  49% (83597/170120), 46.68 MiB | 89.00 KiB/s   Receiving objects:  49% (84279/170120), 46.86 MiB | 89.00 KiB/s   Receiving objects:  49% (84382/170120), 46.89 MiB | 89.00 KiB/s   Receiving objects:  49% (84464/170120), 46.97 MiB | 78.00 KiB/s   Receiving objects:  49% (84913/170120), 47.02 MiB | 76.00 KiB/s   Receiving objects:  49% (85055/170120), 47.11 MiB | 82.00 KiB/s   Receiving objects:  50% (85060/170120), 47.11 MiB | 82.00 KiB/s   Receiving objects:  50% (85257/170120), 47.18 MiB | 67.00 KiB/s   Receiving objects:  50% (85958/170120), 47.21 MiB | 68.00 KiB/s   Receiving objects:  51% (86762/170120), 47.34 MiB | 76.00 KiB/s   Receiving objects:  51% (86798/170120), 47.34 MiB | 76.00 KiB/s   Receiving objects:  51% (87251/170120), 47.50 MiB | 92.00 KiB/s   Receiving objects:  51% (87425/170120), 47.58 MiB | 93.00 KiB/s   Receiving objects:  51% (87843/170120), 47.62 MiB | 94.00 KiB/s   Receiving objects:  51% (88294/170120), 47.68 MiB | 91.00 KiB/s   Receiving objects:  52% (88463/170120), 47.68 MiB | 91.00 KiB/s   Receiving objects:  52% (89156/170120), 47.76 MiB | 83.00 KiB/s   Receiving objects:  53% (90164/170120), 47.83 MiB | 82.00 KiB/s   Receiving objects:  53% (90252/170120), 47.91 MiB | 83.00 KiB/s   Receiving objects:  53% (90512/170120), 47.99 MiB | 89.00 KiB/s   Receiving objects:  53% (90546/170120), 48.09 MiB | 93.00 KiB/s   Receiving objects:  53% (90568/170120), 48.14 MiB | 89.00 KiB/s   Receiving objects:  53% (90692/170120), 48.17 MiB | 86.00 KiB/s   Receiving objects:  53% (90794/170120), 48.25 MiB | 79.00 KiB/s   Receiving objects:  53% (90816/170120), 48.32 MiB | 62.00 KiB/s   Receiving objects:  53% (90816/170120), 48.40 MiB | 58.00 KiB/s   Receiving objects:  53% (90816/170120), 48.50 MiB | 69.00 KiB/s   Receiving objects:  53% (90816/170120), 48.54 MiB | 69.00 KiB/s   Receiving objects:  53% (90816/170120), 48.61 MiB | 67.00 KiB/s   Receiving objects:  53% (90816/170120), 48.71 MiB | 74.00 KiB/s   Receiving objects:  53% (90816/170120), 48.81 MiB | 79.00 KiB/s   Receiving objects:  53% (90816/170120), 48.93 MiB | 87.00 KiB/s   Receiving objects:  53% (90816/170120), 49.02 MiB | 99.00 KiB/s   Receiving objects:  53% (90816/170120), 49.17 MiB | 116.00 KiB/s   Receiving objects:  53% (90816/170120), 49.30 MiB | 123.00 KiB/s   Receiving objects:  53% (90816/170120), 49.45 MiB | 131.00 KiB/s   Receiving objects:  53% (90816/170120), 49.48 MiB | 122.00 KiB/s   Receiving objects:  53% (90816/170120), 49.55 MiB | 104.00 KiB/s   Receiving objects:  53% (90816/170120), 49.68 MiB | 101.00 KiB/s   Receiving objects:  53% (90816/170120), 49.80 MiB | 98.00 KiB/s   Receiving objects:  53% (90816/170120), 49.88 MiB | 97.00 KiB/s   Receiving objects:  53% (90816/170120), 50.04 MiB | 110.00 KiB/s   Receiving objects:  53% (90816/170120), 50.18 MiB | 127.00 KiB/s   Receiving objects:  53% (90817/170120), 50.31 MiB | 125.00 KiB/s   Receiving objects:  53% (90817/170120), 50.39 MiB | 125.00 KiB/s   Receiving objects:  53% (90817/170120), 50.48 MiB | 116.00 KiB/s   Receiving objects:  53% (90840/170120), 50.59 MiB | 106.00 KiB/s   Receiving objects:  53% (90904/170120), 50.59 MiB | 106.00 KiB/s   Receiving objects:  53% (91022/170120), 50.79 MiB | 104.00 KiB/s   Receiving objects:  53% (91022/170120), 50.86 MiB | 92.00 KiB/s   Receiving objects:  53% (91022/170120), 50.94 MiB | 89.00 KiB/s   Receiving objects:  53% (91022/170120), 50.99 MiB | 91.00 KiB/s   Receiving objects:  53% (91022/170120), 51.07 MiB | 81.00 KiB/s   Receiving objects:  53% (91022/170120), 51.18 MiB | 77.00 KiB/s   Receiving objects:  53% (91022/170120), 51.29 MiB | 85.00 KiB/s   Receiving objects:  53% (91022/170120), 51.36 MiB | 94.00 KiB/s   Receiving objects:  53% (91022/170120), 51.52 MiB | 107.00 KiB/s   Receiving objects:  53% (91227/170120), 51.57 MiB | 104.00 KiB/s   Receiving objects:  53% (91376/170120), 51.64 MiB | 101.00 KiB/s   Receiving objects:  53% (91572/170120), 51.69 MiB | 99.00 KiB/s   Receiving objects:  53% (91685/170120), 51.75 MiB | 91.00 KiB/s   Receiving objects:  53% (91777/170120), 51.80 MiB | 71.00 KiB/s   Receiving objects:  53% (91804/170120), 51.89 MiB | 61.00 KiB/s   Receiving objects:  53% (91804/170120), 52.00 MiB | 70.00 KiB/s   Receiving objects:  53% (91804/170120), 52.12 MiB | 79.00 KiB/s   Receiving objects:  53% (91804/170120), 52.26 MiB | 95.00 KiB/s   Receiving objects:  53% (91804/170120), 52.32 MiB | 102.00 KiB/s   Receiving objects:  53% (91804/170120), 52.39 MiB | 102.00 KiB/s   Receiving objects:  53% (91804/170120), 52.48 MiB | 93.00 KiB/s   Receiving objects:  53% (91804/170120), 52.55 MiB | 96.00 KiB/s   Receiving objects:  53% (91804/170120), 52.71 MiB | 102.00 KiB/s   Receiving objects:  53% (91805/170120), 52.77 MiB | 96.00 KiB/s   Receiving objects:  53% (91806/170120), 52.93 MiB | 104.00 KiB/s   Receiving objects:  53% (91806/170120), 52.99 MiB | 111.00 KiB/s   Receiving objects:  53% (91806/170120), 53.08 MiB | 106.00 KiB/s   Receiving objects:  53% (91806/170120), 53.19 MiB | 97.00 KiB/s   Receiving objects:  53% (91806/170120), 53.27 MiB | 94.00 KiB/s   Receiving objects:  53% (91806/170120), 53.39 MiB | 94.00 KiB/s   Receiving objects:  53% (91806/170120), 53.49 MiB | 95.00 KiB/s   Receiving objects:  53% (91806/170120), 53.54 MiB | 95.00 KiB/s   Receiving objects:  53% (91806/170120), 53.67 MiB | 96.00 KiB/s   Receiving objects:  53% (91806/170120), 53.75 MiB | 96.00 KiB/s   Receiving objects:  53% (91820/170120), 53.78 MiB | 90.00 KiB/s   Receiving objects:  53% (91844/170120), 53.83 MiB | 77.00 KiB/s   Receiving objects:  53% (91844/170120), 53.93 MiB | 75.00 KiB/s   error: index-pack died of signal 15
fatal: index-pack failed

	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl.launchCommandIn(CliGitAPIImpl.java:2042)
	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl.launchCommandWithCredentials(CliGitAPIImpl.java:1761)
	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl.access$400(CliGitAPIImpl.java:72)
	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl$1.execute(CliGitAPIImpl.java:442)
	at org.jenkinsci.plugins.gitclient.CliGitAPIImpl$2.execute(CliGitAPIImpl.java:655)
	at org.jenkinsci.plugins.gitclient.RemoteGitImpl$CommandInvocationHandler$1.call(RemoteGitImpl.java:153)
	at org.jenkinsci.plugins.gitclient.RemoteGitImpl$CommandInvocationHandler$1.call(RemoteGitImpl.java:146)
	at hudson.remoting.UserRequest.perform(UserRequest.java:212)
	at hudson.remoting.UserRequest.perform(UserRequest.java:54)
	at hudson.remoting.Request$2.run(Request.java:369)
	at hudson.remoting.InterceptingExecutorService$1.call(InterceptingExecutorService.java:72)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617)
	at java.lang.Thread.run(Thread.java:748)
	Suppressed: hudson.remoting.Channel$CallSiteStackTrace: Remote call to ubuntu-1
		at hudson.remoting.Channel.attachCallSiteStackTrace(Channel.java:1741)
		at hudson.remoting.UserRequest$ExceptionResponse.retrieve(UserRequest.java:357)
		at hudson.remoting.Channel.call(Channel.java:955)
		at org.jenkinsci.plugins.gitclient.RemoteGitImpl$CommandInvocationHandler.execute(RemoteGitImpl.java:146)
		at sun.reflect.GeneratedMethodAccessor927.invoke(Unknown Source)
		at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
		at java.lang.reflect.Method.invoke(Method.java:498)
		at org.jenkinsci.plugins.gitclient.RemoteGitImpl$CommandInvocationHandler.invoke(RemoteGitImpl.java:132)
		at com.sun.proxy.$Proxy134.execute(Unknown Source)
		at hudson.plugins.git.GitSCM.retrieveChanges(GitSCM.java:1152)
		at hudson.plugins.git.GitSCM.checkout(GitSCM.java:1192)
		at hudson.scm.SCM.checkout(SCM.java:504)
		at hudson.model.AbstractProject.checkout(AbstractProject.java:1208)
		at hudson.model.AbstractBuild$AbstractBuildExecution.defaultCheckout(AbstractBuild.java:574)
		at jenkins.scm.SCMCheckoutStrategy.checkout(SCMCheckoutStrategy.java:86)
		at hudson.model.AbstractBuild$AbstractBuildExecution.run(AbstractBuild.java:499)
		at hudson.model.Run.execute(Run.java:1810)
		at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
		at hudson.model.ResourceController.execute(ResourceController.java:97)
		at hudson.model.Executor.run(Executor.java:429)
ERROR: Error cloning remote repo 'origin'
Retrying after 10 seconds
No credentials specified
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision a1286edb040a5d368a76d6c9c809c5cf0c080ec8 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f a1286edb040a5d368a76d6c9c809c5cf0c080ec8
Commit message: "MINOR: Fix race condition in Streams tests (#6748)"
 > git rev-list --no-walk 64c2d49cf5c8b1cecbd7601dc2d1577fc606ab1e # timeout=10
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: No tool found matching GRADLE_4_10_2_HOME
[kafka-trunk-jdk11] $ /bin/bash -xe /tmp/jenkins1057419709863486164.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk11/ws/.gradle>
+ /bin/gradle
/tmp/jenkins1057419709863486164.sh: line 4: /bin/gradle: No such file or directory
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
ERROR: No tool found matching GRADLE_4_10_2_HOME
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user cshapi@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com