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 2021/03/23 22:02:39 UTC

Build failed in Jenkins: Kafka » kafka-trunk-jdk11 #632

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

Changes:

[github] MINOR: Remove duplicate `createKafkaMetricsContext` (#10376)


------------------------------------------
[...truncated 3.70 MB...]

ControllerChannelManagerTest > testUpdateMetadataDoesNotIncludePartitionsWithoutLeaderAndIsr() STARTED

ControllerChannelManagerTest > testUpdateMetadataDoesNotIncludePartitionsWithoutLeaderAndIsr() PASSED

ControllerChannelManagerTest > testMixedDeleteAndNotDeleteStopReplicaRequests() STARTED

ControllerChannelManagerTest > testMixedDeleteAndNotDeleteStopReplicaRequests() PASSED

ControllerChannelManagerTest > testLeaderAndIsrInterBrokerProtocolVersion() STARTED

ControllerChannelManagerTest > testLeaderAndIsrInterBrokerProtocolVersion() PASSED

ControllerChannelManagerTest > testUpdateMetadataRequestSent() STARTED

ControllerChannelManagerTest > testUpdateMetadataRequestSent() PASSED

ControllerChannelManagerTest > testUpdateMetadataRequestDuringTopicDeletion() STARTED

ControllerChannelManagerTest > testUpdateMetadataRequestDuringTopicDeletion() PASSED

ControllerChannelManagerTest > testUpdateMetadataIncludesLiveOrShuttingDownBrokers() STARTED

ControllerChannelManagerTest > testUpdateMetadataIncludesLiveOrShuttingDownBrokers() PASSED

ControllerChannelManagerTest > testStopReplicaRequestSent() STARTED

ControllerChannelManagerTest > testStopReplicaRequestSent() PASSED

ControllerChannelManagerTest > testStopReplicaRequestsWhileTopicDeletionStarted() STARTED

ControllerChannelManagerTest > testStopReplicaRequestsWhileTopicDeletionStarted() PASSED

ControllerChannelManagerTest > testLeaderAndIsrRequestSent() STARTED

ControllerChannelManagerTest > testLeaderAndIsrRequestSent() PASSED

ControllerChannelManagerTest > testStopReplicaRequestWithoutDeletePartitionWhileTopicDeletionStarted() STARTED

ControllerChannelManagerTest > testStopReplicaRequestWithoutDeletePartitionWhileTopicDeletionStarted() PASSED

FeatureZNodeTest > testDecodeFailOnInvalidFeatures() STARTED

FeatureZNodeTest > testDecodeFailOnInvalidFeatures() PASSED

FeatureZNodeTest > testEncodeDecode() STARTED

FeatureZNodeTest > testEncodeDecode() PASSED

FeatureZNodeTest > testDecodeSuccess() STARTED

FeatureZNodeTest > testDecodeSuccess() PASSED

FeatureZNodeTest > testDecodeFailOnInvalidVersionAndStatus() STARTED

FeatureZNodeTest > testDecodeFailOnInvalidVersionAndStatus() PASSED

ExtendedAclStoreTest > shouldHaveCorrectPaths() STARTED

ExtendedAclStoreTest > shouldHaveCorrectPaths() PASSED

ExtendedAclStoreTest > shouldRoundTripChangeNode() STARTED

ExtendedAclStoreTest > shouldRoundTripChangeNode() PASSED

ExtendedAclStoreTest > shouldThrowFromEncodeOnLiteral() STARTED

ExtendedAclStoreTest > shouldThrowFromEncodeOnLiteral() PASSED

ExtendedAclStoreTest > shouldThrowIfConstructedWithLiteral() STARTED

ExtendedAclStoreTest > shouldThrowIfConstructedWithLiteral() PASSED

ExtendedAclStoreTest > shouldWriteChangesToTheWritePath() STARTED

ExtendedAclStoreTest > shouldWriteChangesToTheWritePath() PASSED

ExtendedAclStoreTest > shouldHaveCorrectPatternType() STARTED

ExtendedAclStoreTest > shouldHaveCorrectPatternType() PASSED

DefaultMessageFormatterTest > [1] name=print nothing, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@76fc367e, value = [B@47245091), properties=Map(print.value -> false), expected= STARTED

DefaultMessageFormatterTest > [1] name=print nothing, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@76fc367e, value = [B@47245091), properties=Map(print.value -> false), expected= PASSED

DefaultMessageFormatterTest > [2] name=print key, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@749e88a9, value = [B@537dd0f6), properties=Map(print.key -> true, print.value -> false), expected=someKey
 STARTED

DefaultMessageFormatterTest > [2] name=print key, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@749e88a9, value = [B@537dd0f6), properties=Map(print.key -> true, print.value -> false), expected=someKey
 PASSED

DefaultMessageFormatterTest > [3] name=print value, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@2c6347f4, value = [B@57a220be), properties=Map(), expected=someValue
 STARTED

DefaultMessageFormatterTest > [3] name=print value, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@2c6347f4, value = [B@57a220be), properties=Map(), expected=someValue
 PASSED

DefaultMessageFormatterTest > [4] name=print empty timestamp, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, NoTimestampType = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@3882339c, value = [B@f6b8535), properties=Map(print.timestamp -> true, print.value -> false), expected=NO_TIMESTAMP
 STARTED

DefaultMessageFormatterTest > [4] name=print empty timestamp, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, NoTimestampType = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@3882339c, value = [B@f6b8535), properties=Map(print.timestamp -> true, print.value -> false), expected=NO_TIMESTAMP
 PASSED

DefaultMessageFormatterTest > [5] name=print log append time timestamp, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, LogAppendTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@39013fcb, value = [B@7fe04f85), properties=Map(print.timestamp -> true, print.value -> false), expected=LogAppendTime:1234
 STARTED

DefaultMessageFormatterTest > [5] name=print log append time timestamp, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, LogAppendTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@39013fcb, value = [B@7fe04f85), properties=Map(print.timestamp -> true, print.value -> false), expected=LogAppendTime:1234
 PASSED

DefaultMessageFormatterTest > [6] name=print create time timestamp, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@56578d36, value = [B@546f8e4), properties=Map(print.timestamp -> true, print.value -> false), expected=CreateTime:1234
 STARTED

DefaultMessageFormatterTest > [6] name=print create time timestamp, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@56578d36, value = [B@546f8e4), properties=Map(print.timestamp -> true, print.value -> false), expected=CreateTime:1234
 PASSED

DefaultMessageFormatterTest > [7] name=print partition, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@358970e0, value = [B@48689db3), properties=Map(print.partition -> true, print.value -> false), expected=Partition:9
 STARTED

DefaultMessageFormatterTest > [7] name=print partition, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@358970e0, value = [B@48689db3), properties=Map(print.partition -> true, print.value -> false), expected=Partition:9
 PASSED

DefaultMessageFormatterTest > [8] name=print offset, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@223c87b5, value = [B@100fcace), properties=Map(print.offset -> true, print.value -> false), expected=Offset:9876
 STARTED

DefaultMessageFormatterTest > [8] name=print offset, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@223c87b5, value = [B@100fcace), properties=Map(print.offset -> true, print.value -> false), expected=Offset:9876
 PASSED

DefaultMessageFormatterTest > [9] name=print headers, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@6effb65f, value = [B@62f62b36), properties=Map(print.headers -> true, print.value -> false), expected=h1:v1,h2:v2
 STARTED

DefaultMessageFormatterTest > [9] name=print headers, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@6effb65f, value = [B@62f62b36), properties=Map(print.headers -> true, print.value -> false), expected=h1:v1,h2:v2
 PASSED

DefaultMessageFormatterTest > [10] name=print empty headers, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [], isReadOnly = false), key = [B@26f6adf8, value = [B@5b7d3158), properties=Map(print.headers -> true, print.value -> false), expected=NO_HEADERS
 STARTED

DefaultMessageFormatterTest > [10] name=print empty headers, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [], isReadOnly = false), key = [B@26f6adf8, value = [B@5b7d3158), properties=Map(print.headers -> true, print.value -> false), expected=NO_HEADERS
 PASSED

DefaultMessageFormatterTest > [11] name=print all possible fields with default delimiters, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@4519ac0a, value = [B@69cf2d8d), properties=Map(print.key -> true, print.headers -> true, print.partition -> true, print.offset -> true, print.timestamp -> true, print.value -> true), expected=CreateTime:1234	Partition:9	Offset:9876	h1:v1,h2:v2	someKey	someValue
 STARTED

DefaultMessageFormatterTest > [11] name=print all possible fields with default delimiters, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@4519ac0a, value = [B@69cf2d8d), properties=Map(print.key -> true, print.headers -> true, print.partition -> true, print.offset -> true, print.timestamp -> true, print.value -> true), expected=CreateTime:1234	Partition:9	Offset:9876	h1:v1,h2:v2	someKey	someValue
 PASSED

DefaultMessageFormatterTest > [12] name=print all possible fields with custom delimiters, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@7ac5d421, value = [B@4880cdd0), properties=Map(line.separator -> ^, print.key -> true, headers.separator -> #, print.headers -> true, key.separator -> |, print.partition -> true, print.offset -> true, print.timestamp -> true, print.value -> true), expected=CreateTime:1234|Partition:9|Offset:9876|h1:v1#h2:v2|someKey|someValue^ STARTED

DefaultMessageFormatterTest > [12] name=print all possible fields with custom delimiters, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@7ac5d421, value = [B@4880cdd0), properties=Map(line.separator -> ^, print.key -> true, headers.separator -> #, print.headers -> true, key.separator -> |, print.partition -> true, print.offset -> true, print.timestamp -> true, print.value -> true), expected=CreateTime:1234|Partition:9|Offset:9876|h1:v1#h2:v2|someKey|someValue^ PASSED

DefaultMessageFormatterTest > [13] name=print key with custom deserializer, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@40f14136, value = [B@5042afe0), properties=Map(print.key -> true, print.headers -> true, print.value -> true, key.deserializer -> unit.kafka.tools.UpperCaseDeserializer), expected=h1:v1,h2:v2	SOMEKEY	someValue
 STARTED

DefaultMessageFormatterTest > [13] name=print key with custom deserializer, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@40f14136, value = [B@5042afe0), properties=Map(print.key -> true, print.headers -> true, print.value -> true, key.deserializer -> unit.kafka.tools.UpperCaseDeserializer), expected=h1:v1,h2:v2	SOMEKEY	someValue
 PASSED

DefaultMessageFormatterTest > [14] name=print value with custom deserializer, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@60be9b, value = [B@45182cd8), properties=Map(print.key -> true, print.headers -> true, print.value -> true, value.deserializer -> unit.kafka.tools.UpperCaseDeserializer), expected=h1:v1,h2:v2	someKey	SOMEVALUE
 STARTED

DefaultMessageFormatterTest > [14] name=print value with custom deserializer, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@60be9b, value = [B@45182cd8), properties=Map(print.key -> true, print.headers -> true, print.value -> true, value.deserializer -> unit.kafka.tools.UpperCaseDeserializer), expected=h1:v1,h2:v2	someKey	SOMEVALUE
 PASSED

DefaultMessageFormatterTest > [15] name=print headers with custom deserializer, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@51168bdb, value = [B@e6bbdf1), properties=Map(print.key -> true, print.headers -> true, print.value -> true, headers.deserializer -> unit.kafka.tools.UpperCaseDeserializer), expected=h1:V1,h2:V2	someKey	someValue
 STARTED

DefaultMessageFormatterTest > [15] name=print headers with custom deserializer, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@51168bdb, value = [B@e6bbdf1), properties=Map(print.key -> true, print.headers -> true, print.value -> true, headers.deserializer -> unit.kafka.tools.UpperCaseDeserializer), expected=h1:V1,h2:V2	someKey	someValue
 PASSED

DefaultMessageFormatterTest > [16] name=print key and value, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@bfa4ec1, value = [B@f00dd8a), properties=Map(print.key -> true, print.value -> true), expected=someKey	someValue
 STARTED

DefaultMessageFormatterTest > [16] name=print key and value, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@bfa4ec1, value = [B@f00dd8a), properties=Map(print.key -> true, print.value -> true), expected=someKey	someValue
 PASSED

DefaultMessageFormatterTest > [17] name=print fields in the beginning, middle and the end, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@6d5c03d5, value = [B@797dcfe), properties=Map(print.key -> true, print.value -> true, print.partition -> true), expected=Partition:9	someKey	someValue
 STARTED

DefaultMessageFormatterTest > [17] name=print fields in the beginning, middle and the end, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@6d5c03d5, value = [B@797dcfe), properties=Map(print.key -> true, print.value -> true, print.partition -> true), expected=Partition:9	someKey	someValue
 PASSED

DefaultMessageFormatterTest > [18] name=null value without custom null literal, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@1a13aba9, value = null), properties=Map(print.key -> true), expected=someKey	null
 STARTED

DefaultMessageFormatterTest > [18] name=null value without custom null literal, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@1a13aba9, value = null), properties=Map(print.key -> true), expected=someKey	null
 PASSED

DefaultMessageFormatterTest > [19] name=null value with custom null literal, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@25b82f21, value = null), properties=Map(print.key -> true, null.literal -> NULL), expected=someKey	NULL
 STARTED

DefaultMessageFormatterTest > [19] name=null value with custom null literal, record=ConsumerRecord(topic = someTopic, partition = 9, leaderEpoch = null, offset = 9876, CreateTime = 1234, serialized key size = 0, serialized value size = 0, headers = RecordHeaders(headers = [RecordHeader(key = h1, value = [118, 49]), RecordHeader(key = h2, value = [118, 50])], isReadOnly = false), key = [B@25b82f21, value = null), properties=Map(print.key -> true, null.literal -> NULL), expected=someKey	NULL
 PASSED

3496 tests completed, 1 failed, 7 skipped

> Task :core:test FAILED

FAILURE: Build completed with 4 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':connect:mirror:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk11/ws/connect/mirror/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'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/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.
==============================================================================

3: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':streams:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/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.
==============================================================================

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

BUILD FAILED in 1h 29m 55s
257 actionable tasks: 220 executed, 37 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
[Checks API] No suitable checks publisher found.
Not sending mail to unregistered user github@hugo-hirsch.de

Build failed in Jenkins: Kafka » kafka-trunk-jdk11 #634

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

Changes:

[github] KAFKA-12173 Migrate streams:streams-scala module to JUnit 5 (#9858)


------------------------------------------
[...truncated 3.69 MB...]

AuthorizerIntegrationTest > testTransactionalProducerInitTransactionsNoDescribeTransactionalIdAcl() PASSED

AuthorizerIntegrationTest > testAuthorizeByResourceTypeDenyTakesPrecedence() STARTED

AuthorizerIntegrationTest > testAuthorizeByResourceTypeDenyTakesPrecedence() PASSED

AuthorizerIntegrationTest > testUnauthorizedDeleteRecordsWithDescribe() STARTED

AuthorizerIntegrationTest > testUnauthorizedDeleteRecordsWithDescribe() PASSED

AuthorizerIntegrationTest > testCreateTopicAuthorizationWithClusterCreate() STARTED

AuthorizerIntegrationTest > testCreateTopicAuthorizationWithClusterCreate() PASSED

AuthorizerIntegrationTest > testOffsetFetchWithTopicAndGroupRead() STARTED

AuthorizerIntegrationTest > testOffsetFetchWithTopicAndGroupRead() PASSED

AuthorizerIntegrationTest > testCommitWithTopicDescribe() STARTED

AuthorizerIntegrationTest > testCommitWithTopicDescribe() PASSED

AuthorizerIntegrationTest > testAuthorizationWithTopicExisting() STARTED

AuthorizerIntegrationTest > testAuthorizationWithTopicExisting() PASSED

AuthorizerIntegrationTest > testUnauthorizedDeleteRecordsWithoutDescribe() STARTED

AuthorizerIntegrationTest > testUnauthorizedDeleteRecordsWithoutDescribe() PASSED

AuthorizerIntegrationTest > testMetadataWithTopicDescribe() STARTED

AuthorizerIntegrationTest > testMetadataWithTopicDescribe() PASSED

AuthorizerIntegrationTest > testProduceWithTopicDescribe() STARTED

AuthorizerIntegrationTest > testProduceWithTopicDescribe() PASSED

AuthorizerIntegrationTest > testDescribeGroupApiWithNoGroupAcl() STARTED

AuthorizerIntegrationTest > testDescribeGroupApiWithNoGroupAcl() PASSED

AuthorizerIntegrationTest > testPatternSubscriptionMatchingInternalTopic() STARTED

AuthorizerIntegrationTest > testPatternSubscriptionMatchingInternalTopic() PASSED

AuthorizerIntegrationTest > testSendOffsetsWithNoConsumerGroupDescribeAccess() STARTED

AuthorizerIntegrationTest > testSendOffsetsWithNoConsumerGroupDescribeAccess() PASSED

AuthorizerIntegrationTest > testListTransactionsAuthorization() STARTED

AuthorizerIntegrationTest > testListTransactionsAuthorization() PASSED

AuthorizerIntegrationTest > testOffsetFetchTopicDescribe() STARTED

AuthorizerIntegrationTest > testOffsetFetchTopicDescribe() PASSED

AuthorizerIntegrationTest > testCommitWithTopicAndGroupRead() STARTED

AuthorizerIntegrationTest > testCommitWithTopicAndGroupRead() PASSED

AuthorizerIntegrationTest > testIdempotentProducerNoIdempotentWriteAclInInitProducerId() STARTED

AuthorizerIntegrationTest > testIdempotentProducerNoIdempotentWriteAclInInitProducerId() PASSED

AuthorizerIntegrationTest > testSimpleConsumeWithExplicitSeekAndNoGroupAccess() STARTED

AuthorizerIntegrationTest > testSimpleConsumeWithExplicitSeekAndNoGroupAccess() PASSED

SslProducerSendTest > testSendNonCompressedMessageWithCreateTime() STARTED

SslProducerSendTest > testSendNonCompressedMessageWithCreateTime() PASSED

SslProducerSendTest > testClose() STARTED

SslProducerSendTest > testClose() PASSED

SslProducerSendTest > testFlush() STARTED

SslProducerSendTest > testFlush() PASSED

SslProducerSendTest > testSendToPartition() STARTED

SslProducerSendTest > testSendToPartition() PASSED

SslProducerSendTest > testSendOffset() STARTED

SslProducerSendTest > testSendOffset() PASSED

SslProducerSendTest > testSendCompressedMessageWithCreateTime() STARTED

SslProducerSendTest > testSendCompressedMessageWithCreateTime() PASSED

SslProducerSendTest > testCloseWithZeroTimeoutFromCallerThread() STARTED

SslProducerSendTest > testCloseWithZeroTimeoutFromCallerThread() PASSED

SslProducerSendTest > testCloseWithZeroTimeoutFromSenderThread() STARTED

SslProducerSendTest > testCloseWithZeroTimeoutFromSenderThread() PASSED

SslProducerSendTest > testSendBeforeAndAfterPartitionExpansion() STARTED

SslProducerSendTest > testSendBeforeAndAfterPartitionExpansion() PASSED

ProducerCompressionTest > [1] compression=none STARTED

ProducerCompressionTest > [1] compression=none PASSED

ProducerCompressionTest > [2] compression=gzip STARTED

ProducerCompressionTest > [2] compression=gzip PASSED

ProducerCompressionTest > [3] compression=snappy STARTED

ProducerCompressionTest > [3] compression=snappy PASSED

ProducerCompressionTest > [4] compression=lz4 STARTED

ProducerCompressionTest > [4] compression=lz4 PASSED

ProducerCompressionTest > [5] compression=zstd STARTED

ProducerCompressionTest > [5] compression=zstd PASSED

MetricsTest > testMetrics() STARTED

MetricsTest > testMetrics() PASSED

ProducerFailureHandlingTest > testCannotSendToInternalTopic() STARTED

ProducerFailureHandlingTest > testCannotSendToInternalTopic() PASSED

ProducerFailureHandlingTest > testTooLargeRecordWithAckOne() STARTED

ProducerFailureHandlingTest > testTooLargeRecordWithAckOne() PASSED

ProducerFailureHandlingTest > testWrongBrokerList() STARTED

ProducerFailureHandlingTest > testWrongBrokerList() PASSED

ProducerFailureHandlingTest > testNotEnoughReplicas() STARTED

ProducerFailureHandlingTest > testNotEnoughReplicas() PASSED

ProducerFailureHandlingTest > testResponseTooLargeForReplicationWithAckAll() STARTED

ProducerFailureHandlingTest > testResponseTooLargeForReplicationWithAckAll() PASSED

ProducerFailureHandlingTest > testNonExistentTopic() STARTED

ProducerFailureHandlingTest > testNonExistentTopic() PASSED

ProducerFailureHandlingTest > testInvalidPartition() STARTED

ProducerFailureHandlingTest > testInvalidPartition() PASSED

ProducerFailureHandlingTest > testSendAfterClosed() STARTED

ProducerFailureHandlingTest > testSendAfterClosed() PASSED

ProducerFailureHandlingTest > testTooLargeRecordWithAckZero() STARTED

ProducerFailureHandlingTest > testTooLargeRecordWithAckZero() PASSED

ProducerFailureHandlingTest > testPartitionTooLargeForReplicationWithAckAll() STARTED

ProducerFailureHandlingTest > testPartitionTooLargeForReplicationWithAckAll() PASSED

ProducerFailureHandlingTest > testNotEnoughReplicasAfterBrokerShutdown() STARTED

ProducerFailureHandlingTest > testNotEnoughReplicasAfterBrokerShutdown() PASSED

ApiVersionTest > testApiVersionUniqueIds() STARTED

ApiVersionTest > testApiVersionUniqueIds() PASSED

ApiVersionTest > testMinSupportedVersionFor() STARTED

ApiVersionTest > testMinSupportedVersionFor() PASSED

ApiVersionTest > testShortVersion() STARTED

ApiVersionTest > testShortVersion() PASSED

ApiVersionTest > shouldReturnAllKeysWhenMagicIsCurrentValueAndThrottleMsIsDefaultThrottle() STARTED

ApiVersionTest > shouldReturnAllKeysWhenMagicIsCurrentValueAndThrottleMsIsDefaultThrottle() PASSED

ApiVersionTest > testApply() STARTED

ApiVersionTest > testApply() PASSED

ApiVersionTest > testMetadataQuorumApisAreDisabled() STARTED

ApiVersionTest > testMetadataQuorumApisAreDisabled() PASSED

ApiVersionTest > shouldReturnFeatureKeysWhenMagicIsCurrentValueAndThrottleMsIsDefaultThrottle() STARTED

ApiVersionTest > shouldReturnFeatureKeysWhenMagicIsCurrentValueAndThrottleMsIsDefaultThrottle() PASSED

ApiVersionTest > shouldCreateApiResponseOnlyWithKeysSupportedByMagicValue() STARTED

ApiVersionTest > shouldCreateApiResponseOnlyWithKeysSupportedByMagicValue() PASSED

ApiVersionTest > testApiVersionValidator() STARTED

ApiVersionTest > testApiVersionValidator() PASSED

3496 tests completed, 2 failed, 7 skipped

> Task :core:test FAILED

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://ci-builds.apache.org/job/Kafka/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://ci-builds.apache.org/job/Kafka/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 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.8.3/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 48m 46s
257 actionable tasks: 220 executed, 37 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
[Checks API] No suitable checks publisher found.
Not sending mail to unregistered user github@hugo-hirsch.de

Build failed in Jenkins: Kafka » kafka-trunk-jdk11 #633

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

Changes:

[github] KAFKA-12524: Remove deprecated segments() (#10379)


------------------------------------------
[...truncated 3.70 MB...]

PartitionLockTest > testAppendReplicaFetchWithSchedulerCheckForShrinkIsr() STARTED

PartitionLockTest > testAppendReplicaFetchWithSchedulerCheckForShrinkIsr() PASSED

PartitionLockTest > testGetReplicaWithUpdateAssignmentAndIsr() STARTED

PartitionLockTest > testGetReplicaWithUpdateAssignmentAndIsr() PASSED

JsonValueTest > testJsonObjectIterator() STARTED

JsonValueTest > testJsonObjectIterator() PASSED

JsonValueTest > testDecodeLong() STARTED

JsonValueTest > testDecodeLong() PASSED

JsonValueTest > testAsJsonObject() STARTED

JsonValueTest > testAsJsonObject() PASSED

JsonValueTest > testDecodeDouble() STARTED

JsonValueTest > testDecodeDouble() PASSED

JsonValueTest > testDecodeOption() STARTED

JsonValueTest > testDecodeOption() PASSED

JsonValueTest > testDecodeString() STARTED

JsonValueTest > testDecodeString() PASSED

JsonValueTest > testJsonValueToString() STARTED

JsonValueTest > testJsonValueToString() PASSED

JsonValueTest > testAsJsonObjectOption() STARTED

JsonValueTest > testAsJsonObjectOption() PASSED

JsonValueTest > testAsJsonArrayOption() STARTED

JsonValueTest > testAsJsonArrayOption() PASSED

JsonValueTest > testAsJsonArray() STARTED

JsonValueTest > testAsJsonArray() PASSED

JsonValueTest > testJsonValueHashCode() STARTED

JsonValueTest > testJsonValueHashCode() PASSED

JsonValueTest > testDecodeInt() STARTED

JsonValueTest > testDecodeInt() PASSED

JsonValueTest > testDecodeMap() STARTED

JsonValueTest > testDecodeMap() PASSED

JsonValueTest > testDecodeSeq() STARTED

JsonValueTest > testDecodeSeq() PASSED

JsonValueTest > testJsonObjectGet() STARTED

JsonValueTest > testJsonObjectGet() PASSED

JsonValueTest > testJsonValueEquals() STARTED

JsonValueTest > testJsonValueEquals() PASSED

JsonValueTest > testJsonArrayIterator() STARTED

JsonValueTest > testJsonArrayIterator() PASSED

JsonValueTest > testJsonObjectApply() STARTED

JsonValueTest > testJsonObjectApply() PASSED

JsonValueTest > testDecodeBoolean() STARTED

JsonValueTest > testDecodeBoolean() PASSED

PasswordEncoderTest > testEncoderConfigChange() STARTED

PasswordEncoderTest > testEncoderConfigChange() PASSED

PasswordEncoderTest > testEncodeDecodeAlgorithms() STARTED

PasswordEncoderTest > testEncodeDecodeAlgorithms() PASSED

PasswordEncoderTest > testEncodeDecode() STARTED

PasswordEncoderTest > testEncodeDecode() PASSED

ThrottlerTest > testThrottleDesiredRate() STARTED

ThrottlerTest > testThrottleDesiredRate() PASSED

LoggingTest > testLoggerLevelIsResolved() STARTED

LoggingTest > testLoggerLevelIsResolved() PASSED

LoggingTest > testLog4jControllerIsRegistered() STARTED

LoggingTest > testLog4jControllerIsRegistered() PASSED

LoggingTest > testTypeOfGetLoggers() STARTED

LoggingTest > testTypeOfGetLoggers() PASSED

LoggingTest > testLogName() STARTED

LoggingTest > testLogName() PASSED

LoggingTest > testLogNameOverride() STARTED

LoggingTest > testLogNameOverride() PASSED

TimerTest > testAlreadyExpiredTask() STARTED

TimerTest > testAlreadyExpiredTask() PASSED

TimerTest > testTaskExpiration() STARTED

TimerTest > testTaskExpiration() PASSED

ReplicationUtilsTest > testUpdateLeaderAndIsr() STARTED

ReplicationUtilsTest > testUpdateLeaderAndIsr() PASSED

TopicFilterTest > testIncludeLists() STARTED

TopicFilterTest > testIncludeLists() PASSED

RaftManagerTest > testShutdownIoThread() STARTED

RaftManagerTest > testShutdownIoThread() PASSED

RaftManagerTest > testUncaughtExceptionInIoThread() STARTED

RaftManagerTest > testUncaughtExceptionInIoThread() PASSED

RequestChannelTest > testNonAlterRequestsNotTransformed() STARTED

RequestChannelTest > testNonAlterRequestsNotTransformed() PASSED

RequestChannelTest > testAlterRequests() STARTED

RequestChannelTest > testAlterRequests() PASSED

RequestChannelTest > testJsonRequests() STARTED

RequestChannelTest > testJsonRequests() PASSED

RequestChannelTest > testIncrementalAlterRequests() STARTED

RequestChannelTest > testIncrementalAlterRequests() PASSED

ControllerContextTest > testPartitionFullReplicaAssignmentReturnsEmptyAssignmentIfTopicOrPartitionDoesNotExist() STARTED

ControllerContextTest > testPartitionFullReplicaAssignmentReturnsEmptyAssignmentIfTopicOrPartitionDoesNotExist() PASSED

ControllerContextTest > testPartitionReplicaAssignmentForTopicReturnsEmptyMapIfTopicDoesNotExist() STARTED

ControllerContextTest > testPartitionReplicaAssignmentForTopicReturnsEmptyMapIfTopicDoesNotExist() PASSED

ControllerContextTest > testPreferredReplicaImbalanceMetric() STARTED

ControllerContextTest > testPreferredReplicaImbalanceMetric() PASSED

ControllerContextTest > testPartitionReplicaAssignmentForTopicReturnsExpectedReplicaAssignments() STARTED

ControllerContextTest > testPartitionReplicaAssignmentForTopicReturnsExpectedReplicaAssignments() PASSED

ControllerContextTest > testReassignTo() STARTED

ControllerContextTest > testReassignTo() PASSED

ControllerContextTest > testPartitionReplicaAssignment() STARTED

ControllerContextTest > testPartitionReplicaAssignment() PASSED

ControllerContextTest > testUpdatePartitionFullReplicaAssignmentUpdatesReplicaAssignment() STARTED

ControllerContextTest > testUpdatePartitionFullReplicaAssignmentUpdatesReplicaAssignment() PASSED

ControllerContextTest > testReassignToIdempotence() STARTED

ControllerContextTest > testReassignToIdempotence() PASSED

ControllerContextTest > testPartitionReplicaAssignmentReturnsEmptySeqIfTopicOrPartitionDoesNotExist() STARTED

ControllerContextTest > testPartitionReplicaAssignmentReturnsEmptySeqIfTopicOrPartitionDoesNotExist() PASSED

TransactionsWithMaxInFlightOneTest > testTransactionalProducerSingleBrokerMaxInFlightOne() STARTED

TransactionsWithMaxInFlightOneTest > testTransactionalProducerSingleBrokerMaxInFlightOne() PASSED

3496 tests completed, 2 failed, 7 skipped

> Task :core:test FAILED

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':connect:runtime:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/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.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':streams:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/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.
==============================================================================

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

BUILD FAILED in 1h 26m 48s
257 actionable tasks: 220 executed, 37 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
[Checks API] No suitable checks publisher found.
Not sending mail to unregistered user github@hugo-hirsch.de