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/18 21:03:33 UTC

Build failed in Jenkins: Kafka » kafka-trunk-jdk15 #642

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

Changes:

[github] KAFKA-10357: Add setup method to internal topics (#10317)

[github] MINOR: Fix BaseHashTable sizing (#10334)

[github] KAFKA-12382: add a README for KIP-500 (#10227)

[github] MINOR: Start the broker-to-controller channel for request forwarding (#10340)

[github] MINOR: Remove use of `NoSuchElementException` in `KafkaMetadataLog` (#10344)

[github] MINOR: Move `configurations.all` to be a child of `allprojects` (#10349)


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

FetchSessionTest > testPrivilegedSessionHandling() STARTED

FetchSessionTest > testPrivilegedSessionHandling() PASSED

FetchSessionTest > testSessionCache() STARTED

FetchSessionTest > testSessionCache() PASSED

FetchSessionTest > testLastFetchedEpoch() STARTED

FetchSessionTest > testLastFetchedEpoch() PASSED

FetchSessionTest > testDeprioritizesPartitionsWithRecordsOnly() STARTED

FetchSessionTest > testDeprioritizesPartitionsWithRecordsOnly() PASSED

FetchSessionTest > testFetchSessionExpiration() STARTED

FetchSessionTest > testFetchSessionExpiration() PASSED

FetchSessionTest > testZeroSizeFetchSession() STARTED

FetchSessionTest > testZeroSizeFetchSession() PASSED

FetchSessionTest > testNewSessionId() STARTED

FetchSessionTest > testNewSessionId() PASSED

PartitionLockTest > testNoLockContentionWithoutIsrUpdate() STARTED

PartitionLockTest > testNoLockContentionWithoutIsrUpdate() PASSED

PartitionLockTest > testAppendReplicaFetchWithUpdateIsr() STARTED

PartitionLockTest > testAppendReplicaFetchWithUpdateIsr() PASSED

PartitionLockTest > testAppendReplicaFetchWithSchedulerCheckForShrinkIsr() STARTED

PartitionLockTest > testAppendReplicaFetchWithSchedulerCheckForShrinkIsr() PASSED

PartitionLockTest > testGetReplicaWithUpdateAssignmentAndIsr() STARTED

PartitionLockTest > testGetReplicaWithUpdateAssignmentAndIsr() PASSED

PartitionTest > testMakeLeaderDoesNotUpdateEpochCacheForOldFormats() STARTED

PartitionTest > testMakeLeaderDoesNotUpdateEpochCacheForOldFormats() PASSED

PartitionTest > testIsrExpansion() STARTED

PartitionTest > testIsrExpansion() PASSED

PartitionTest > testReadRecordEpochValidationForLeader() STARTED

PartitionTest > testReadRecordEpochValidationForLeader() PASSED

PartitionTest > testAlterIsrUnknownTopic() STARTED

PartitionTest > testAlterIsrUnknownTopic() PASSED

PartitionTest > testIsrNotShrunkIfUpdateFails() STARTED

PartitionTest > testIsrNotShrunkIfUpdateFails() PASSED

PartitionTest > testFetchOffsetForTimestampEpochValidationForFollower() STARTED

PartitionTest > testFetchOffsetForTimestampEpochValidationForFollower() PASSED

PartitionTest > testIsrNotExpandedIfUpdateFails() STARTED

PartitionTest > testIsrNotExpandedIfUpdateFails() PASSED

PartitionTest > testLogConfigDirtyAsBrokerUpdated() STARTED

PartitionTest > testLogConfigDirtyAsBrokerUpdated() PASSED

PartitionTest > testAddAndRemoveMetrics() STARTED

PartitionTest > testAddAndRemoveMetrics() PASSED

PartitionTest > testListOffsetIsolationLevels() STARTED

PartitionTest > testListOffsetIsolationLevels() PASSED

PartitionTest > testAppendRecordsAsFollowerBelowLogStartOffset() STARTED

PartitionTest > testAppendRecordsAsFollowerBelowLogStartOffset() PASSED

PartitionTest > testFetchLatestOffsetIncludesLeaderEpoch() STARTED

PartitionTest > testFetchLatestOffsetIncludesLeaderEpoch() PASSED

PartitionTest > testUnderReplicatedPartitionsCorrectSemantics() STARTED

PartitionTest > testUnderReplicatedPartitionsCorrectSemantics() PASSED

PartitionTest > testFetchOffsetSnapshotEpochValidationForFollower() STARTED

PartitionTest > testFetchOffsetSnapshotEpochValidationForFollower() PASSED

PartitionTest > testMaybeShrinkIsr() STARTED

PartitionTest > testMaybeShrinkIsr() PASSED

PartitionTest > testLogConfigNotDirty() STARTED

PartitionTest > testLogConfigNotDirty() PASSED

PartitionTest > testMonotonicOffsetsAfterLeaderChange() STARTED

PartitionTest > testMonotonicOffsetsAfterLeaderChange() PASSED

PartitionTest > testUpdateAssignmentAndIsr() STARTED

PartitionTest > testUpdateAssignmentAndIsr() PASSED

PartitionTest > testMakeFollowerWithNoLeaderIdChange() STARTED

PartitionTest > testMakeFollowerWithNoLeaderIdChange() PASSED

PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException() STARTED

PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException() PASSED

PartitionTest > testFollowerDoesNotJoinISRUntilCaughtUpToOffsetWithinCurrentLeaderEpoch() STARTED

PartitionTest > testFollowerDoesNotJoinISRUntilCaughtUpToOffsetWithinCurrentLeaderEpoch() PASSED

PartitionTest > testSingleInFlightAlterIsr() STARTED

PartitionTest > testSingleInFlightAlterIsr() PASSED

PartitionTest > testShouldNotShrinkIsrIfFollowerCaughtUpToLogEnd() STARTED

PartitionTest > testShouldNotShrinkIsrIfFollowerCaughtUpToLogEnd() PASSED

PartitionTest > testFetchOffsetSnapshotEpochValidationForLeader() STARTED

PartitionTest > testFetchOffsetSnapshotEpochValidationForLeader() PASSED

PartitionTest > testOffsetForLeaderEpochValidationForLeader() STARTED

PartitionTest > testOffsetForLeaderEpochValidationForLeader() PASSED

PartitionTest > testAtMinIsr() STARTED

PartitionTest > testAtMinIsr() PASSED

PartitionTest > testAlterIsrInvalidVersion() STARTED

PartitionTest > testAlterIsrInvalidVersion() PASSED

PartitionTest > testOffsetForLeaderEpochValidationForFollower() STARTED

PartitionTest > testOffsetForLeaderEpochValidationForFollower() PASSED

PartitionTest > testMakeLeaderUpdatesEpochCache() STARTED

PartitionTest > testMakeLeaderUpdatesEpochCache() PASSED

PartitionTest > testUseCheckpointToInitializeHighWatermark() STARTED

PartitionTest > testUseCheckpointToInitializeHighWatermark() PASSED

PartitionTest > testMaybeReplaceCurrentWithFutureReplicaDifferentBaseOffsets() STARTED

PartitionTest > testMaybeReplaceCurrentWithFutureReplicaDifferentBaseOffsets() PASSED

PartitionTest > testFetchOffsetForTimestampEpochValidationForLeader() STARTED

PartitionTest > testFetchOffsetForTimestampEpochValidationForLeader() PASSED

PartitionTest > testMakeFollowerWithWithFollowerAppendRecords() STARTED

PartitionTest > testMakeFollowerWithWithFollowerAppendRecords() PASSED

PartitionTest > testShouldNotShrinkIsrIfPreviousFetchIsCaughtUp() STARTED

PartitionTest > testShouldNotShrinkIsrIfPreviousFetchIsCaughtUp() PASSED

PartitionTest > testGetReplica() STARTED

PartitionTest > testGetReplica() PASSED

PartitionTest > testReadRecordEpochValidationForFollower() STARTED

PartitionTest > testReadRecordEpochValidationForFollower() PASSED

PartitionTest > testAlterIsrUnexpectedError() STARTED

PartitionTest > testAlterIsrUnexpectedError() PASSED

PartitionTest > testZkIsrManagerAsyncCallback() STARTED

PartitionTest > testZkIsrManagerAsyncCallback() PASSED

PartitionTest > testLogConfigDirtyAsTopicUpdated() STARTED

PartitionTest > testLogConfigDirtyAsTopicUpdated() PASSED

PartitionTest > testMaybeReplaceCurrentWithFutureReplica() STARTED

PartitionTest > testMaybeReplaceCurrentWithFutureReplica() PASSED

PartitionTest > testLastFetchedOffsetValidation() STARTED

PartitionTest > testLastFetchedOffsetValidation() PASSED

PartitionTest > testUpdateFollowerFetchState() STARTED

PartitionTest > testUpdateFollowerFetchState() PASSED

ReplicaTest > testCannotIncrementLogStartOffsetPastHighWatermark() STARTED

ReplicaTest > testCannotIncrementLogStartOffsetPastHighWatermark() PASSED

ReplicaTest > testSegmentDeletionWithHighWatermarkInitialization() STARTED

ReplicaTest > testSegmentDeletionWithHighWatermarkInitialization() PASSED

ReplicaTest > testCannotDeleteSegmentsAtOrAboveHighWatermark() STARTED

ReplicaTest > testCannotDeleteSegmentsAtOrAboveHighWatermark() PASSED

FAILURE: Build failed with an exception.

* Where:
Script '<https://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/ws/gradle/rat.gradle'> line: 63

* What went wrong:
Execution failed for task ':rat'.
> Found 1 files with unknown licenses.

* 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 20m 54s
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

Jenkins build is back to normal : Kafka » kafka-trunk-jdk15 #653

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


Build failed in Jenkins: Kafka » kafka-trunk-jdk15 #652

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

Changes:

[github] KAFKA-3745: Add access to read-only key in value joiner (#10150)


------------------------------------------
[...truncated 3.69 MB...]
AclAuthorizerTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() PASSED

AclAuthorizerTest > testEmptyAclThrowsException() STARTED

AclAuthorizerTest > testEmptyAclThrowsException() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeNoAclFoundOverride() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeNoAclFoundOverride() PASSED

AclAuthorizerTest > testSuperUserWithCustomPrincipalHasAccess() STARTED

AclAuthorizerTest > testSuperUserWithCustomPrincipalHasAccess() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllOperationAce() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllOperationAce() PASSED

AclAuthorizerTest > testAllowAccessWithCustomPrincipal() STARTED

AclAuthorizerTest > testAllowAccessWithCustomPrincipal() PASSED

AclAuthorizerTest > testDeleteAclOnWildcardResource() STARTED

AclAuthorizerTest > testDeleteAclOnWildcardResource() PASSED

AclAuthorizerTest > testAuthorizerZkConfigFromKafkaConfig() STARTED

AclAuthorizerTest > testAuthorizerZkConfigFromKafkaConfig() PASSED

AclAuthorizerTest > testChangeListenerTiming() STARTED

AclAuthorizerTest > testChangeListenerTiming() PASSED

AclAuthorizerTest > testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions() STARTED

AclAuthorizerTest > testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions() PASSED

AclAuthorizerTest > testAuthorzeByResourceTypeSuperUserHasAccess() STARTED

AclAuthorizerTest > testAuthorzeByResourceTypeSuperUserHasAccess() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeMultipleAddAndRemove() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeMultipleAddAndRemove() PASSED

AclAuthorizerTest > testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow() STARTED

AclAuthorizerTest > testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow() PASSED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource() STARTED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeDenyTakesPrecedence() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeDenyTakesPrecedence() PASSED

AclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls() STARTED

AclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllPrincipalAce() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllPrincipalAce() PASSED

AclAuthorizerTest > testAuthorizeWithEmptyResourceName() STARTED

AclAuthorizerTest > testAuthorizeWithEmptyResourceName() PASSED

AclAuthorizerTest > testAuthorizeThrowsOnNonLiteralResource() STARTED

AclAuthorizerTest > testAuthorizeThrowsOnNonLiteralResource() PASSED

AclAuthorizerTest > testDeleteAllAclOnPrefixedResource() STARTED

AclAuthorizerTest > testDeleteAllAclOnPrefixedResource() PASSED

AclAuthorizerTest > testAddAclsOnLiteralResource() STARTED

AclAuthorizerTest > testAddAclsOnLiteralResource() PASSED

AclAuthorizerTest > testGetAclsPrincipal() STARTED

AclAuthorizerTest > testGetAclsPrincipal() PASSED

AclAuthorizerTest > testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet() STARTED

AclAuthorizerTest > testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet() PASSED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource() STARTED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource() PASSED

AclAuthorizerTest > testLoadCache() STARTED

AclAuthorizerTest > testLoadCache() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllHostAce() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllHostAce() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllOperationAce() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllOperationAce() PASSED

AuthorizerInterfaceDefaultTest > testAuthorzeByResourceTypeSuperUserHasAccess() STARTED

AuthorizerInterfaceDefaultTest > testAuthorzeByResourceTypeSuperUserHasAccess() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeMultipleAddAndRemove() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeMultipleAddAndRemove() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeDenyTakesPrecedence() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeDenyTakesPrecedence() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllPrincipalAce() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllPrincipalAce() PASSED

AclEntryTest > testAclJsonConversion() STARTED

AclEntryTest > testAclJsonConversion() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDisableAllowEveryoneOverride() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDisableAllowEveryoneOverride() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllHostAce() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllHostAce() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeEnableAllowEveryOne() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeEnableAllowEveryOne() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllOperationAce() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllOperationAce() PASSED

AuthorizerWrapperTest > testAuthorzeByResourceTypeSuperUserHasAccess() STARTED

AuthorizerWrapperTest > testAuthorzeByResourceTypeSuperUserHasAccess() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeMultipleAddAndRemove() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeMultipleAddAndRemove() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDenyTakesPrecedence() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDenyTakesPrecedence() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllPrincipalAce() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllPrincipalAce() 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

3489 tests completed, 1 failed, 7 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://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/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 24m 51s
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-jdk15 #651

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

Changes:

[github] KAFKA-12500: fix memory leak in thread cache (#10355)


------------------------------------------
[...truncated 3.69 MB...]
AuthorizerIntegrationTest > shouldThrowTransactionalIdAuthorizationExceptionWhenNoTransactionAccessOnEndTransaction() STARTED

AuthorizerIntegrationTest > shouldThrowTransactionalIdAuthorizationExceptionWhenNoTransactionAccessOnEndTransaction() PASSED

AuthorizerIntegrationTest > shouldThrowTransactionalIdAuthorizationExceptionWhenNoTransactionAccessOnSendOffsetsToTxn() STARTED

AuthorizerIntegrationTest > shouldThrowTransactionalIdAuthorizationExceptionWhenNoTransactionAccessOnSendOffsetsToTxn() PASSED

AuthorizerIntegrationTest > testCommitWithNoGroupAccess() STARTED

AuthorizerIntegrationTest > testCommitWithNoGroupAccess() PASSED

AuthorizerIntegrationTest > testTransactionalProducerInitTransactionsNoDescribeTransactionalIdAcl() STARTED

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

3489 tests completed, 1 failed, 7 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://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/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 38m 13s
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-jdk15 #650

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

Changes:

[github] MINOR: Use self-managed mode instead of KIP-500 and nozk (#10362)


------------------------------------------
[...truncated 7.38 MB...]
AclAuthorizerTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() PASSED

AclAuthorizerTest > testEmptyAclThrowsException() STARTED

AclAuthorizerTest > testEmptyAclThrowsException() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeNoAclFoundOverride() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeNoAclFoundOverride() PASSED

AclAuthorizerTest > testSuperUserWithCustomPrincipalHasAccess() STARTED

AclAuthorizerTest > testSuperUserWithCustomPrincipalHasAccess() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllOperationAce() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllOperationAce() PASSED

AclAuthorizerTest > testAllowAccessWithCustomPrincipal() STARTED

AclAuthorizerTest > testAllowAccessWithCustomPrincipal() PASSED

AclAuthorizerTest > testDeleteAclOnWildcardResource() STARTED

AclAuthorizerTest > testDeleteAclOnWildcardResource() PASSED

AclAuthorizerTest > testAuthorizerZkConfigFromKafkaConfig() STARTED

AclAuthorizerTest > testAuthorizerZkConfigFromKafkaConfig() PASSED

AclAuthorizerTest > testChangeListenerTiming() STARTED

AclAuthorizerTest > testChangeListenerTiming() PASSED

AclAuthorizerTest > testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions() STARTED

AclAuthorizerTest > testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions() PASSED

AclAuthorizerTest > testAuthorzeByResourceTypeSuperUserHasAccess() STARTED

AclAuthorizerTest > testAuthorzeByResourceTypeSuperUserHasAccess() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeMultipleAddAndRemove() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeMultipleAddAndRemove() PASSED

AclAuthorizerTest > testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow() STARTED

AclAuthorizerTest > testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow() PASSED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource() STARTED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeDenyTakesPrecedence() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeDenyTakesPrecedence() PASSED

AclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls() STARTED

AclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllPrincipalAce() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllPrincipalAce() PASSED

AclAuthorizerTest > testAuthorizeWithEmptyResourceName() STARTED

AclAuthorizerTest > testAuthorizeWithEmptyResourceName() PASSED

AclAuthorizerTest > testAuthorizeThrowsOnNonLiteralResource() STARTED

AclAuthorizerTest > testAuthorizeThrowsOnNonLiteralResource() PASSED

AclAuthorizerTest > testDeleteAllAclOnPrefixedResource() STARTED

AclAuthorizerTest > testDeleteAllAclOnPrefixedResource() PASSED

AclAuthorizerTest > testAddAclsOnLiteralResource() STARTED

AclAuthorizerTest > testAddAclsOnLiteralResource() PASSED

AclAuthorizerTest > testGetAclsPrincipal() STARTED

AclAuthorizerTest > testGetAclsPrincipal() PASSED

AclAuthorizerTest > testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet() STARTED

AclAuthorizerTest > testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet() PASSED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource() STARTED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource() PASSED

AclAuthorizerTest > testLoadCache() STARTED

AclAuthorizerTest > testLoadCache() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllHostAce() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllHostAce() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllOperationAce() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllOperationAce() PASSED

AuthorizerInterfaceDefaultTest > testAuthorzeByResourceTypeSuperUserHasAccess() STARTED

AuthorizerInterfaceDefaultTest > testAuthorzeByResourceTypeSuperUserHasAccess() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeMultipleAddAndRemove() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeMultipleAddAndRemove() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeDenyTakesPrecedence() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeDenyTakesPrecedence() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllPrincipalAce() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllPrincipalAce() PASSED

AclEntryTest > testAclJsonConversion() STARTED

AclEntryTest > testAclJsonConversion() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDisableAllowEveryoneOverride() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDisableAllowEveryoneOverride() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllHostAce() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllHostAce() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeEnableAllowEveryOne() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeEnableAllowEveryOne() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllOperationAce() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllOperationAce() PASSED

AuthorizerWrapperTest > testAuthorzeByResourceTypeSuperUserHasAccess() STARTED

AuthorizerWrapperTest > testAuthorzeByResourceTypeSuperUserHasAccess() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeMultipleAddAndRemove() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeMultipleAddAndRemove() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDenyTakesPrecedence() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDenyTakesPrecedence() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllPrincipalAce() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllPrincipalAce() 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

3489 tests completed, 1 failed, 7 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://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/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 30m 7s
257 actionable tasks: 250 executed, 7 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-jdk15 #649

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

Changes:

[github] MINOR: Assume unclean shutdown for metadata log (#10363)

[github] KAFKA-12508: Emit records with same value and same timestamp (#10360)


------------------------------------------
[...truncated 3.69 MB...]
UserQuotaTest > testThrottledProducerConsumer() STARTED

UserQuotaTest > testThrottledProducerConsumer() PASSED

UserQuotaTest > testQuotaOverrideDelete() STARTED

UserQuotaTest > testQuotaOverrideDelete() PASSED

UserQuotaTest > testThrottledRequest() STARTED

UserQuotaTest > testThrottledRequest() PASSED

LinuxIoMetricsCollectorTest > testReadProcFile() STARTED

LinuxIoMetricsCollectorTest > testReadProcFile() PASSED

LinuxIoMetricsCollectorTest > testUnableToReadNonexistentProcFile() STARTED

LinuxIoMetricsCollectorTest > testUnableToReadNonexistentProcFile() PASSED

AssignmentStateTest > [1] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(), removing=List(), original=List(), isUnderReplicated=false STARTED

AssignmentStateTest > [1] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(), removing=List(), original=List(), isUnderReplicated=false PASSED

AssignmentStateTest > [2] isr=List(101, 102), replicas=List(101, 102, 103), adding=List(), removing=List(), original=List(), isUnderReplicated=true STARTED

AssignmentStateTest > [2] isr=List(101, 102), replicas=List(101, 102, 103), adding=List(), removing=List(), original=List(), isUnderReplicated=true PASSED

AssignmentStateTest > [3] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(104, 105), removing=List(102), original=List(101, 102, 103), isUnderReplicated=false STARTED

AssignmentStateTest > [3] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(104, 105), removing=List(102), original=List(101, 102, 103), isUnderReplicated=false PASSED

AssignmentStateTest > [4] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(104, 105), removing=List(), original=List(101, 102, 103), isUnderReplicated=false STARTED

AssignmentStateTest > [4] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(104, 105), removing=List(), original=List(101, 102, 103), isUnderReplicated=false PASSED

AssignmentStateTest > [5] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(), removing=List(102), original=List(101, 102, 103), isUnderReplicated=false STARTED

AssignmentStateTest > [5] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(), removing=List(102), original=List(101, 102, 103), isUnderReplicated=false PASSED

AssignmentStateTest > [6] isr=List(102, 103), replicas=List(102, 103), adding=List(101), removing=List(), original=List(102, 103), isUnderReplicated=false STARTED

AssignmentStateTest > [6] isr=List(102, 103), replicas=List(102, 103), adding=List(101), removing=List(), original=List(102, 103), isUnderReplicated=false PASSED

AssignmentStateTest > [7] isr=List(103, 104, 105), replicas=List(101, 102, 103), adding=List(104, 105, 106), removing=List(), original=List(101, 102, 103), isUnderReplicated=false STARTED

AssignmentStateTest > [7] isr=List(103, 104, 105), replicas=List(101, 102, 103), adding=List(104, 105, 106), removing=List(), original=List(101, 102, 103), isUnderReplicated=false PASSED

AssignmentStateTest > [8] isr=List(103, 104, 105), replicas=List(101, 102, 103), adding=List(104, 105, 106), removing=List(), original=List(101, 102, 103), isUnderReplicated=false STARTED

AssignmentStateTest > [8] isr=List(103, 104, 105), replicas=List(101, 102, 103), adding=List(104, 105, 106), removing=List(), original=List(101, 102, 103), isUnderReplicated=false PASSED

AssignmentStateTest > [9] isr=List(103, 104), replicas=List(101, 102, 103), adding=List(104, 105, 106), removing=List(), original=List(101, 102, 103), isUnderReplicated=true STARTED

AssignmentStateTest > [9] isr=List(103, 104), replicas=List(101, 102, 103), adding=List(104, 105, 106), removing=List(), original=List(101, 102, 103), isUnderReplicated=true PASSED

PartitionTest > testMakeLeaderDoesNotUpdateEpochCacheForOldFormats() STARTED

PartitionTest > testMakeLeaderDoesNotUpdateEpochCacheForOldFormats() PASSED

PartitionTest > testIsrExpansion() STARTED

PartitionTest > testIsrExpansion() PASSED

PartitionTest > testReadRecordEpochValidationForLeader() STARTED

PartitionTest > testReadRecordEpochValidationForLeader() PASSED

PartitionTest > testAlterIsrUnknownTopic() STARTED

PartitionTest > testAlterIsrUnknownTopic() PASSED

PartitionTest > testIsrNotShrunkIfUpdateFails() STARTED

PartitionTest > testIsrNotShrunkIfUpdateFails() PASSED

PartitionTest > testFetchOffsetForTimestampEpochValidationForFollower() STARTED

PartitionTest > testFetchOffsetForTimestampEpochValidationForFollower() PASSED

PartitionTest > testIsrNotExpandedIfUpdateFails() STARTED

PartitionTest > testIsrNotExpandedIfUpdateFails() PASSED

PartitionTest > testLogConfigDirtyAsBrokerUpdated() STARTED

PartitionTest > testLogConfigDirtyAsBrokerUpdated() PASSED

PartitionTest > testAddAndRemoveMetrics() STARTED

PartitionTest > testAddAndRemoveMetrics() PASSED

PartitionTest > testListOffsetIsolationLevels() STARTED

PartitionTest > testListOffsetIsolationLevels() PASSED

PartitionTest > testAppendRecordsAsFollowerBelowLogStartOffset() STARTED

PartitionTest > testAppendRecordsAsFollowerBelowLogStartOffset() PASSED

PartitionTest > testFetchLatestOffsetIncludesLeaderEpoch() STARTED

PartitionTest > testFetchLatestOffsetIncludesLeaderEpoch() PASSED

PartitionTest > testUnderReplicatedPartitionsCorrectSemantics() STARTED

PartitionTest > testUnderReplicatedPartitionsCorrectSemantics() PASSED

PartitionTest > testFetchOffsetSnapshotEpochValidationForFollower() STARTED

PartitionTest > testFetchOffsetSnapshotEpochValidationForFollower() PASSED

PartitionTest > testMaybeShrinkIsr() STARTED

PartitionTest > testMaybeShrinkIsr() PASSED

PartitionTest > testLogConfigNotDirty() STARTED

PartitionTest > testLogConfigNotDirty() PASSED

PartitionTest > testMonotonicOffsetsAfterLeaderChange() STARTED

PartitionTest > testMonotonicOffsetsAfterLeaderChange() PASSED

PartitionTest > testUpdateAssignmentAndIsr() STARTED

PartitionTest > testUpdateAssignmentAndIsr() PASSED

PartitionTest > testMakeFollowerWithNoLeaderIdChange() STARTED

PartitionTest > testMakeFollowerWithNoLeaderIdChange() PASSED

PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException() STARTED

PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException() PASSED

PartitionTest > testFollowerDoesNotJoinISRUntilCaughtUpToOffsetWithinCurrentLeaderEpoch() STARTED

PartitionTest > testFollowerDoesNotJoinISRUntilCaughtUpToOffsetWithinCurrentLeaderEpoch() PASSED

PartitionTest > testSingleInFlightAlterIsr() STARTED

PartitionTest > testSingleInFlightAlterIsr() PASSED

PartitionTest > testShouldNotShrinkIsrIfFollowerCaughtUpToLogEnd() STARTED

PartitionTest > testShouldNotShrinkIsrIfFollowerCaughtUpToLogEnd() PASSED

PartitionTest > testFetchOffsetSnapshotEpochValidationForLeader() STARTED

PartitionTest > testFetchOffsetSnapshotEpochValidationForLeader() PASSED

PartitionTest > testOffsetForLeaderEpochValidationForLeader() STARTED

PartitionTest > testOffsetForLeaderEpochValidationForLeader() PASSED

PartitionTest > testAtMinIsr() STARTED

PartitionTest > testAtMinIsr() PASSED

PartitionTest > testAlterIsrInvalidVersion() STARTED

PartitionTest > testAlterIsrInvalidVersion() PASSED

PartitionTest > testOffsetForLeaderEpochValidationForFollower() STARTED

PartitionTest > testOffsetForLeaderEpochValidationForFollower() PASSED

PartitionTest > testMakeLeaderUpdatesEpochCache() STARTED

PartitionTest > testMakeLeaderUpdatesEpochCache() PASSED

PartitionTest > testUseCheckpointToInitializeHighWatermark() STARTED

PartitionTest > testUseCheckpointToInitializeHighWatermark() PASSED

PartitionTest > testMaybeReplaceCurrentWithFutureReplicaDifferentBaseOffsets() STARTED

PartitionTest > testMaybeReplaceCurrentWithFutureReplicaDifferentBaseOffsets() PASSED

PartitionTest > testFetchOffsetForTimestampEpochValidationForLeader() STARTED

PartitionTest > testFetchOffsetForTimestampEpochValidationForLeader() PASSED

PartitionTest > testMakeFollowerWithWithFollowerAppendRecords() STARTED

PartitionTest > testMakeFollowerWithWithFollowerAppendRecords() PASSED

PartitionTest > testShouldNotShrinkIsrIfPreviousFetchIsCaughtUp() STARTED

PartitionTest > testShouldNotShrinkIsrIfPreviousFetchIsCaughtUp() PASSED

PartitionTest > testGetReplica() STARTED

PartitionTest > testGetReplica() PASSED

PartitionTest > testReadRecordEpochValidationForFollower() STARTED

PartitionTest > testReadRecordEpochValidationForFollower() PASSED

PartitionTest > testAlterIsrUnexpectedError() STARTED

PartitionTest > testAlterIsrUnexpectedError() PASSED

PartitionTest > testZkIsrManagerAsyncCallback() STARTED

PartitionTest > testZkIsrManagerAsyncCallback() PASSED

PartitionTest > testLogConfigDirtyAsTopicUpdated() STARTED

PartitionTest > testLogConfigDirtyAsTopicUpdated() PASSED

PartitionTest > testMaybeReplaceCurrentWithFutureReplica() STARTED

PartitionTest > testMaybeReplaceCurrentWithFutureReplica() PASSED

PartitionTest > testLastFetchedOffsetValidation() STARTED

PartitionTest > testLastFetchedOffsetValidation() PASSED

PartitionTest > testUpdateFollowerFetchState() STARTED

PartitionTest > testUpdateFollowerFetchState() PASSED

3489 tests completed, 1 failed, 7 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://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/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 31m 49s
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-jdk15 #648

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

Changes:

[github] KAFKA-12318: system tests need to fetch Topic IDs via Admin Client instead of via ZooKeeper (#10286)


------------------------------------------
[...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

3489 tests completed, 1 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 ':connect:runtime:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/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 ':core:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/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 27m 52s
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-jdk15 #647

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

Changes:

[github] MINOR: The new KIP-500 code should treat cluster ID as a string (#10357)

[github] KAFKA-12253: Add tests that cover all of the cases for ReplicatedLog's validateOffsetAndEpoch (#10276)

[github] KAFKA-12440; ClusterId validation for Vote, BeginQuorum, EndQuorum and FetchSnapshot (#10289)

[github] KAFKA-9189: Use MetadataCache instead of ZK during controlled shutdown to avoid hang (#10361)


------------------------------------------
[...truncated 3.71 MB...]

AclAuthorizerTest > testDeleteAclOnWildcardResource() STARTED

AclAuthorizerTest > testDeleteAclOnWildcardResource() PASSED

AclAuthorizerTest > testAuthorizerZkConfigFromKafkaConfig() STARTED

AclAuthorizerTest > testAuthorizerZkConfigFromKafkaConfig() PASSED

AclAuthorizerTest > testChangeListenerTiming() STARTED

AclAuthorizerTest > testChangeListenerTiming() PASSED

AclAuthorizerTest > testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions() STARTED

AclAuthorizerTest > testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions() PASSED

AclAuthorizerTest > testAuthorzeByResourceTypeSuperUserHasAccess() STARTED

AclAuthorizerTest > testAuthorzeByResourceTypeSuperUserHasAccess() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeMultipleAddAndRemove() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeMultipleAddAndRemove() PASSED

AclAuthorizerTest > testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow() STARTED

AclAuthorizerTest > testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow() PASSED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource() STARTED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeDenyTakesPrecedence() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeDenyTakesPrecedence() PASSED

AclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls() STARTED

AclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllPrincipalAce() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllPrincipalAce() PASSED

AclAuthorizerTest > testAuthorizeWithEmptyResourceName() STARTED

AclAuthorizerTest > testAuthorizeWithEmptyResourceName() PASSED

AclAuthorizerTest > testAuthorizeThrowsOnNonLiteralResource() STARTED

AclAuthorizerTest > testAuthorizeThrowsOnNonLiteralResource() PASSED

AclAuthorizerTest > testDeleteAllAclOnPrefixedResource() STARTED

AclAuthorizerTest > testDeleteAllAclOnPrefixedResource() PASSED

AclAuthorizerTest > testAddAclsOnLiteralResource() STARTED

AclAuthorizerTest > testAddAclsOnLiteralResource() PASSED

AclAuthorizerTest > testGetAclsPrincipal() STARTED

AclAuthorizerTest > testGetAclsPrincipal() PASSED

AclAuthorizerTest > testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet() STARTED

AclAuthorizerTest > testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet() PASSED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource() STARTED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource() PASSED

AclAuthorizerTest > testLoadCache() STARTED

AclAuthorizerTest > testLoadCache() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllHostAce() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllHostAce() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllOperationAce() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllOperationAce() PASSED

AuthorizerInterfaceDefaultTest > testAuthorzeByResourceTypeSuperUserHasAccess() STARTED

AuthorizerInterfaceDefaultTest > testAuthorzeByResourceTypeSuperUserHasAccess() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeMultipleAddAndRemove() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeMultipleAddAndRemove() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeDenyTakesPrecedence() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeDenyTakesPrecedence() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllPrincipalAce() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllPrincipalAce() PASSED

AclEntryTest > testAclJsonConversion() STARTED

AclEntryTest > testAclJsonConversion() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDisableAllowEveryoneOverride() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDisableAllowEveryoneOverride() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllHostAce() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllHostAce() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeEnableAllowEveryOne() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeEnableAllowEveryOne() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllOperationAce() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllOperationAce() PASSED

AuthorizerWrapperTest > testAuthorzeByResourceTypeSuperUserHasAccess() STARTED

AuthorizerWrapperTest > testAuthorzeByResourceTypeSuperUserHasAccess() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeMultipleAddAndRemove() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeMultipleAddAndRemove() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDenyTakesPrecedence() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDenyTakesPrecedence() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllPrincipalAce() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllPrincipalAce() 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

3489 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:mirror:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/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-jdk15/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 ':core:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/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 28m 9s
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-jdk15 #646

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

Changes:

[github] MINOR: Remove inexistent parameter in doc of `LogManager#getOrCreateLog` (#10359)


------------------------------------------
[...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

3480 tests completed, 1 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 ':connect:runtime:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/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 ':core:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/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 40m 36s
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-jdk15 #645

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

Changes:

[github] KAFKA-10070: parameterize Connect unit tests to remove code duplication (#10299)


------------------------------------------
[...truncated 3.69 MB...]
UserQuotaTest > testThrottledProducerConsumer() STARTED

UserQuotaTest > testThrottledProducerConsumer() PASSED

UserQuotaTest > testQuotaOverrideDelete() STARTED

UserQuotaTest > testQuotaOverrideDelete() PASSED

UserQuotaTest > testThrottledRequest() STARTED

UserQuotaTest > testThrottledRequest() PASSED

LinuxIoMetricsCollectorTest > testReadProcFile() STARTED

LinuxIoMetricsCollectorTest > testReadProcFile() PASSED

LinuxIoMetricsCollectorTest > testUnableToReadNonexistentProcFile() STARTED

LinuxIoMetricsCollectorTest > testUnableToReadNonexistentProcFile() PASSED

AssignmentStateTest > [1] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(), removing=List(), original=List(), isUnderReplicated=false STARTED

AssignmentStateTest > [1] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(), removing=List(), original=List(), isUnderReplicated=false PASSED

AssignmentStateTest > [2] isr=List(101, 102), replicas=List(101, 102, 103), adding=List(), removing=List(), original=List(), isUnderReplicated=true STARTED

AssignmentStateTest > [2] isr=List(101, 102), replicas=List(101, 102, 103), adding=List(), removing=List(), original=List(), isUnderReplicated=true PASSED

AssignmentStateTest > [3] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(104, 105), removing=List(102), original=List(101, 102, 103), isUnderReplicated=false STARTED

AssignmentStateTest > [3] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(104, 105), removing=List(102), original=List(101, 102, 103), isUnderReplicated=false PASSED

AssignmentStateTest > [4] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(104, 105), removing=List(), original=List(101, 102, 103), isUnderReplicated=false STARTED

AssignmentStateTest > [4] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(104, 105), removing=List(), original=List(101, 102, 103), isUnderReplicated=false PASSED

AssignmentStateTest > [5] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(), removing=List(102), original=List(101, 102, 103), isUnderReplicated=false STARTED

AssignmentStateTest > [5] isr=List(101, 102, 103), replicas=List(101, 102, 103), adding=List(), removing=List(102), original=List(101, 102, 103), isUnderReplicated=false PASSED

AssignmentStateTest > [6] isr=List(102, 103), replicas=List(102, 103), adding=List(101), removing=List(), original=List(102, 103), isUnderReplicated=false STARTED

AssignmentStateTest > [6] isr=List(102, 103), replicas=List(102, 103), adding=List(101), removing=List(), original=List(102, 103), isUnderReplicated=false PASSED

AssignmentStateTest > [7] isr=List(103, 104, 105), replicas=List(101, 102, 103), adding=List(104, 105, 106), removing=List(), original=List(101, 102, 103), isUnderReplicated=false STARTED

AssignmentStateTest > [7] isr=List(103, 104, 105), replicas=List(101, 102, 103), adding=List(104, 105, 106), removing=List(), original=List(101, 102, 103), isUnderReplicated=false PASSED

AssignmentStateTest > [8] isr=List(103, 104, 105), replicas=List(101, 102, 103), adding=List(104, 105, 106), removing=List(), original=List(101, 102, 103), isUnderReplicated=false STARTED

AssignmentStateTest > [8] isr=List(103, 104, 105), replicas=List(101, 102, 103), adding=List(104, 105, 106), removing=List(), original=List(101, 102, 103), isUnderReplicated=false PASSED

AssignmentStateTest > [9] isr=List(103, 104), replicas=List(101, 102, 103), adding=List(104, 105, 106), removing=List(), original=List(101, 102, 103), isUnderReplicated=true STARTED

AssignmentStateTest > [9] isr=List(103, 104), replicas=List(101, 102, 103), adding=List(104, 105, 106), removing=List(), original=List(101, 102, 103), isUnderReplicated=true PASSED

PartitionTest > testMakeLeaderDoesNotUpdateEpochCacheForOldFormats() STARTED

PartitionTest > testMakeLeaderDoesNotUpdateEpochCacheForOldFormats() PASSED

PartitionTest > testIsrExpansion() STARTED

PartitionTest > testIsrExpansion() PASSED

PartitionTest > testReadRecordEpochValidationForLeader() STARTED

PartitionTest > testReadRecordEpochValidationForLeader() PASSED

PartitionTest > testAlterIsrUnknownTopic() STARTED

PartitionTest > testAlterIsrUnknownTopic() PASSED

PartitionTest > testIsrNotShrunkIfUpdateFails() STARTED

PartitionTest > testIsrNotShrunkIfUpdateFails() PASSED

PartitionTest > testFetchOffsetForTimestampEpochValidationForFollower() STARTED

PartitionTest > testFetchOffsetForTimestampEpochValidationForFollower() PASSED

PartitionTest > testIsrNotExpandedIfUpdateFails() STARTED

PartitionTest > testIsrNotExpandedIfUpdateFails() PASSED

PartitionTest > testLogConfigDirtyAsBrokerUpdated() STARTED

PartitionTest > testLogConfigDirtyAsBrokerUpdated() PASSED

PartitionTest > testAddAndRemoveMetrics() STARTED

PartitionTest > testAddAndRemoveMetrics() PASSED

PartitionTest > testListOffsetIsolationLevels() STARTED

PartitionTest > testListOffsetIsolationLevels() PASSED

PartitionTest > testAppendRecordsAsFollowerBelowLogStartOffset() STARTED

PartitionTest > testAppendRecordsAsFollowerBelowLogStartOffset() PASSED

PartitionTest > testFetchLatestOffsetIncludesLeaderEpoch() STARTED

PartitionTest > testFetchLatestOffsetIncludesLeaderEpoch() PASSED

PartitionTest > testUnderReplicatedPartitionsCorrectSemantics() STARTED

PartitionTest > testUnderReplicatedPartitionsCorrectSemantics() PASSED

PartitionTest > testFetchOffsetSnapshotEpochValidationForFollower() STARTED

PartitionTest > testFetchOffsetSnapshotEpochValidationForFollower() PASSED

PartitionTest > testMaybeShrinkIsr() STARTED

PartitionTest > testMaybeShrinkIsr() PASSED

PartitionTest > testLogConfigNotDirty() STARTED

PartitionTest > testLogConfigNotDirty() PASSED

PartitionTest > testMonotonicOffsetsAfterLeaderChange() STARTED

PartitionTest > testMonotonicOffsetsAfterLeaderChange() PASSED

PartitionTest > testUpdateAssignmentAndIsr() STARTED

PartitionTest > testUpdateAssignmentAndIsr() PASSED

PartitionTest > testMakeFollowerWithNoLeaderIdChange() STARTED

PartitionTest > testMakeFollowerWithNoLeaderIdChange() PASSED

PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException() STARTED

PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException() PASSED

PartitionTest > testFollowerDoesNotJoinISRUntilCaughtUpToOffsetWithinCurrentLeaderEpoch() STARTED

PartitionTest > testFollowerDoesNotJoinISRUntilCaughtUpToOffsetWithinCurrentLeaderEpoch() PASSED

PartitionTest > testSingleInFlightAlterIsr() STARTED

PartitionTest > testSingleInFlightAlterIsr() PASSED

PartitionTest > testShouldNotShrinkIsrIfFollowerCaughtUpToLogEnd() STARTED

PartitionTest > testShouldNotShrinkIsrIfFollowerCaughtUpToLogEnd() PASSED

PartitionTest > testFetchOffsetSnapshotEpochValidationForLeader() STARTED

PartitionTest > testFetchOffsetSnapshotEpochValidationForLeader() PASSED

PartitionTest > testOffsetForLeaderEpochValidationForLeader() STARTED

PartitionTest > testOffsetForLeaderEpochValidationForLeader() PASSED

PartitionTest > testAtMinIsr() STARTED

PartitionTest > testAtMinIsr() PASSED

PartitionTest > testAlterIsrInvalidVersion() STARTED

PartitionTest > testAlterIsrInvalidVersion() PASSED

PartitionTest > testOffsetForLeaderEpochValidationForFollower() STARTED

PartitionTest > testOffsetForLeaderEpochValidationForFollower() PASSED

PartitionTest > testMakeLeaderUpdatesEpochCache() STARTED

PartitionTest > testMakeLeaderUpdatesEpochCache() PASSED

PartitionTest > testUseCheckpointToInitializeHighWatermark() STARTED

PartitionTest > testUseCheckpointToInitializeHighWatermark() PASSED

PartitionTest > testMaybeReplaceCurrentWithFutureReplicaDifferentBaseOffsets() STARTED

PartitionTest > testMaybeReplaceCurrentWithFutureReplicaDifferentBaseOffsets() PASSED

PartitionTest > testFetchOffsetForTimestampEpochValidationForLeader() STARTED

PartitionTest > testFetchOffsetForTimestampEpochValidationForLeader() PASSED

PartitionTest > testMakeFollowerWithWithFollowerAppendRecords() STARTED

PartitionTest > testMakeFollowerWithWithFollowerAppendRecords() PASSED

PartitionTest > testShouldNotShrinkIsrIfPreviousFetchIsCaughtUp() STARTED

PartitionTest > testShouldNotShrinkIsrIfPreviousFetchIsCaughtUp() PASSED

PartitionTest > testGetReplica() STARTED

PartitionTest > testGetReplica() PASSED

PartitionTest > testReadRecordEpochValidationForFollower() STARTED

PartitionTest > testReadRecordEpochValidationForFollower() PASSED

PartitionTest > testAlterIsrUnexpectedError() STARTED

PartitionTest > testAlterIsrUnexpectedError() PASSED

PartitionTest > testZkIsrManagerAsyncCallback() STARTED

PartitionTest > testZkIsrManagerAsyncCallback() PASSED

PartitionTest > testLogConfigDirtyAsTopicUpdated() STARTED

PartitionTest > testLogConfigDirtyAsTopicUpdated() PASSED

PartitionTest > testMaybeReplaceCurrentWithFutureReplica() STARTED

PartitionTest > testMaybeReplaceCurrentWithFutureReplica() PASSED

PartitionTest > testLastFetchedOffsetValidation() STARTED

PartitionTest > testLastFetchedOffsetValidation() PASSED

PartitionTest > testUpdateFollowerFetchState() STARTED

PartitionTest > testUpdateFollowerFetchState() PASSED

3480 tests completed, 1 failed, 7 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://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/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 45m 52s
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-jdk15 #644

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

Changes:

[github] KAFKA-10697: Remove ProduceResponse.responses (#10332)

[github] KAFKA-12503: inform threads to resize their cache instead of doing so for them (#10356)


------------------------------------------
[...truncated 7.38 MB...]

AclAuthorizerTest > testSuperUserWithCustomPrincipalHasAccess() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllOperationAce() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllOperationAce() PASSED

AclAuthorizerTest > testAllowAccessWithCustomPrincipal() STARTED

AclAuthorizerTest > testAllowAccessWithCustomPrincipal() PASSED

AclAuthorizerTest > testDeleteAclOnWildcardResource() STARTED

AclAuthorizerTest > testDeleteAclOnWildcardResource() PASSED

AclAuthorizerTest > testAuthorizerZkConfigFromKafkaConfig() STARTED

AclAuthorizerTest > testAuthorizerZkConfigFromKafkaConfig() PASSED

AclAuthorizerTest > testChangeListenerTiming() STARTED

AclAuthorizerTest > testChangeListenerTiming() PASSED

AclAuthorizerTest > testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions() STARTED

AclAuthorizerTest > testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions() PASSED

AclAuthorizerTest > testAuthorzeByResourceTypeSuperUserHasAccess() STARTED

AclAuthorizerTest > testAuthorzeByResourceTypeSuperUserHasAccess() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeMultipleAddAndRemove() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeMultipleAddAndRemove() PASSED

AclAuthorizerTest > testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow() STARTED

AclAuthorizerTest > testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow() PASSED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource() STARTED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeDenyTakesPrecedence() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeDenyTakesPrecedence() PASSED

AclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls() STARTED

AclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls() PASSED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllPrincipalAce() STARTED

AclAuthorizerTest > testAuthorizeByResourceTypeWithAllPrincipalAce() PASSED

AclAuthorizerTest > testAuthorizeWithEmptyResourceName() STARTED

AclAuthorizerTest > testAuthorizeWithEmptyResourceName() PASSED

AclAuthorizerTest > testAuthorizeThrowsOnNonLiteralResource() STARTED

AclAuthorizerTest > testAuthorizeThrowsOnNonLiteralResource() PASSED

AclAuthorizerTest > testDeleteAllAclOnPrefixedResource() STARTED

AclAuthorizerTest > testDeleteAllAclOnPrefixedResource() PASSED

AclAuthorizerTest > testAddAclsOnLiteralResource() STARTED

AclAuthorizerTest > testAddAclsOnLiteralResource() PASSED

AclAuthorizerTest > testGetAclsPrincipal() STARTED

AclAuthorizerTest > testGetAclsPrincipal() PASSED

AclAuthorizerTest > testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet() STARTED

AclAuthorizerTest > testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet() PASSED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource() STARTED

AclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource() PASSED

AclAuthorizerTest > testLoadCache() STARTED

AclAuthorizerTest > testLoadCache() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllHostAce() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllHostAce() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllOperationAce() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllOperationAce() PASSED

AuthorizerInterfaceDefaultTest > testAuthorzeByResourceTypeSuperUserHasAccess() STARTED

AuthorizerInterfaceDefaultTest > testAuthorzeByResourceTypeSuperUserHasAccess() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeMultipleAddAndRemove() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeMultipleAddAndRemove() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeDenyTakesPrecedence() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeDenyTakesPrecedence() PASSED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllPrincipalAce() STARTED

AuthorizerInterfaceDefaultTest > testAuthorizeByResourceTypeWithAllPrincipalAce() PASSED

AclEntryTest > testAclJsonConversion() STARTED

AclEntryTest > testAclJsonConversion() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDisableAllowEveryoneOverride() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDisableAllowEveryoneOverride() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllHostAce() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllHostAce() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeIsolationUnrelatedDenyWontDominateAllow() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWildcardResourceDenyDominate() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeEnableAllowEveryOne() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeEnableAllowEveryOne() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllOperationAce() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllOperationAce() PASSED

AuthorizerWrapperTest > testAuthorzeByResourceTypeSuperUserHasAccess() STARTED

AuthorizerWrapperTest > testAuthorzeByResourceTypeSuperUserHasAccess() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypePrefixedResourceDenyDominate() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeMultipleAddAndRemove() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeMultipleAddAndRemove() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDenyTakesPrecedence() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeDenyTakesPrecedence() PASSED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllPrincipalAce() STARTED

AuthorizerWrapperTest > testAuthorizeByResourceTypeWithAllPrincipalAce() 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

3480 tests completed, 1 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 ':tools:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/ws/tools/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-jdk15/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 30m 50s
257 actionable tasks: 250 executed, 7 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-jdk15 #643

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

Changes:

[github] MINOR: Exclude KIP-500.md from rat check (#10354)


------------------------------------------
[...truncated 3.69 MB...]
AuthorizerIntegrationTest > shouldThrowTransactionalIdAuthorizationExceptionWhenNoTransactionAccessOnEndTransaction() STARTED

AuthorizerIntegrationTest > shouldThrowTransactionalIdAuthorizationExceptionWhenNoTransactionAccessOnEndTransaction() PASSED

AuthorizerIntegrationTest > shouldThrowTransactionalIdAuthorizationExceptionWhenNoTransactionAccessOnSendOffsetsToTxn() STARTED

AuthorizerIntegrationTest > shouldThrowTransactionalIdAuthorizationExceptionWhenNoTransactionAccessOnSendOffsetsToTxn() PASSED

AuthorizerIntegrationTest > testCommitWithNoGroupAccess() STARTED

AuthorizerIntegrationTest > testCommitWithNoGroupAccess() PASSED

AuthorizerIntegrationTest > testTransactionalProducerInitTransactionsNoDescribeTransactionalIdAcl() STARTED

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

3480 tests completed, 1 failed, 7 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://ci-builds.apache.org/job/Kafka/job/kafka-trunk-jdk15/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 37m 15s
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