See <https://builds.apache.org/job/kafka-trunk-jdk11/678/display/redirect?page=changes>
Changes:
[github] MINOR: Remove zkclient dependency (#7036)
------------------------------------------
[...truncated 6.47 MB...]
org.apache.kafka.streams.scala.WordCountTest > testShouldCountWords STARTED
org.apache.kafka.streams.scala.WordCountTest > testShouldCountWords 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.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.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.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.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.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.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.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
> 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 ':connect:runtime:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/connect/runtime/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 48m 38s
178 actionable tasks: 175 executed, 3 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 noreply@github.com
|