Skip to content

[fix][broker] Avoid block markDeletePosition forward when skip lost entries #21561

[fix][broker] Avoid block markDeletePosition forward when skip lost entries

[fix][broker] Avoid block markDeletePosition forward when skip lost entries #21561

Re-run triggered October 14, 2024 12:18
Status Failure
Total duration 23m 49s
Artifacts 28

pulsar-ci.yaml

on: pull_request
Preconditions
9s
Preconditions
Build and License check
9m 21s
Build and License check
Matrix: unit-tests
Build Pulsar docker image
23m 21s
Build Pulsar docker image
Matrix: Build Pulsar java-test-image docker image
CI - Unit - Upload Coverage
0s
CI - Unit - Upload Coverage
Run CodeQL Analysis
0s
Run CodeQL Analysis
Matrix: system-tests
Matrix: flaky-system-tests
Matrix: integration-tests
CI - System - Upload Coverage
2m 48s
CI - System - Upload Coverage
CI - Integration - Upload Coverage
1m 36s
CI - Integration - Upload Coverage
Build Pulsar on MacOS
8m 54s
Build Pulsar on MacOS
OWASP dependency check
0s
OWASP dependency check
Delete system test docker image artifact
12s
Delete system test docker image artifact
Delete integration test docker image artifact
13s
Delete integration test docker image artifact
Pulsar CI checks completed
8s
Pulsar CI checks completed
Fit to window
Zoom out
Zoom in

Annotations

4 errors and 56 warnings
CI - Unit - Brokers - Broker Group 1
Process completed with exit code 1.
OneWayReplicatorUsingGlobalZKTest.cleanup: pulsar-broker/src/test/java/org/apache/pulsar/broker/service/OneWayReplicatorUsingGlobalZKTest.java#L60
org.apache.pulsar.client.admin.PulsarAdminException$ServerSideErrorException: --- An unexpected error occurred in the server --- Message: org.apache.bookkeeper.mledger.ManagedLedgerException$BadVersionException: org.apache.pulsar.metadata.api.MetadataStoreException$BadVersionException: org.apache.zookeeper.KeeperException$BadVersionException: KeeperErrorCode = BadVersion for /managed-ledgers/public/default/persistent/tp_-fdbdb712-2f13-434e-9b32-428edf6479c5-partition-1/pulsar.repl.r2 Stacktrace: org.apache.pulsar.broker.service.BrokerServiceException$PersistenceException: org.apache.bookkeeper.mledger.ManagedLedgerException$BadVersionException: org.apache.pulsar.metadata.api.MetadataStoreException$BadVersionException: org.apache.zookeeper.KeeperException$BadVersionException: KeeperErrorCode = BadVersion for /managed-ledgers/public/default/persistent/tp_-fdbdb712-2f13-434e-9b32-428edf6479c5-partition-1/pulsar.repl.r2 at org.apache.pulsar.broker.service.persistent.PersistentTopic$6.deleteLedgerFailed(PersistentTopic.java:1546) at org.apache.bookkeeper.mledger.impl.ManagedLedgerImpl.lambda$asyncDelete$35(ManagedLedgerImpl.java:2978) at java.base/java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:863) at java.base/java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:841) at java.base/java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:510) at java.base/java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:2194) at org.apache.bookkeeper.mledger.impl.ManagedLedgerImpl.lambda$asyncTruncate$58(ManagedLedgerImpl.java:4372) at java.base/java.util.concurrent.CompletableFuture.uniExceptionally(CompletableFuture.java:990) at java.base/java.util.concurrent.CompletableFuture$UniExceptionally.tryFire(CompletableFuture.java:974) at java.base/java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:510) at java.base/java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:2194) at org.apache.bookkeeper.mledger.impl.ManagedLedgerImpl$26.clearBacklogFailed(ManagedLedgerImpl.java:4363) at org.apache.bookkeeper.mledger.impl.ManagedCursorImpl$16.markDeleteFailed(ManagedCursorImpl.java:1767) at org.apache.bookkeeper.mledger.impl.ManagedCursorImpl$29.operationFailed(ManagedCursorImpl.java:2988) at org.apache.bookkeeper.mledger.impl.ManagedCursorImpl$32.lambda$operationFailed$0(ManagedCursorImpl.java:3365) at java.base/java.util.concurrent.CompletableFuture$UniRun.tryFire(CompletableFuture.java:787) at java.base/java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:510) at java.base/java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:2179) at org.apache.bookkeeper.mledger.impl.ManagedCursorImpl.lambda$deleteLedgerAsync$39(ManagedCursorImpl.java:3099) at org.apache.bookkeeper.client.LedgerDeleteOp.lambda$initiate$0(LedgerDeleteOp.java:86) at java.base/java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:863) at java.base/java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:841) at java.base/java.util.concurrent.CompletableFuture$Completion.run(CompletableFuture.java:482) at org.apache.bookkeeper.common.util.SingleThreadExecutor.safeRunTask(SingleThreadExecutor.java:137) at org.apache.bookkeeper.common.util.SingleThreadExecutor.run(SingleThreadExecutor.java:113) at io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30) at java.base/java.lang.Thread.run(Thread.java:1583) Caused by: org.apache.bookkeeper.mledger.ManagedLedgerException$BadVersionException: org.apache.pulsar.metadata.api.MetadataStoreException$BadVersionException: org.apache.zookeeper.KeeperException$BadVersionException: KeeperErrorCode = BadVersion for /managed-ledgers/public/default/persistent/tp_-fdbdb712-2f13-434e-9b32-428edf6479c5-partition-1/pulsar.repl.r2
TransactionMetadataStoreServiceTest.testTimeoutTrackerMultiThreading: pulsar-broker/src/test/java/org/apache/pulsar/broker/service/TransactionMetadataStoreServiceTest.java#L292
Condition org.apache.pulsar.broker.service.TransactionMetadataStoreServiceTest$$Lambda/0x00007f83b07fe660 was not fulfilled within 10 seconds.
Pulsar CI checks completed
Process completed with exit code 1.
CI - Unit - Other
Summary: Tests in class org.apache.pulsar.bookie.rackawareness.BookieRackAffinityMappingTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.bookkeeper.mledger.impl.ManagedLedgerFactoryChangeLedgerPathTest created 16 new threads. There are now 26 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.bookkeeper.mledger.impl.ManagedCursorTest created 5 new threads. There are now 15 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.bookkeeper.mledger.offload.filesystem.impl.FileSystemManagedLedgerOffloaderTest created 6 new threads. There are now 16 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.pulsar.functions.utils.FunctionCommonTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.pulsar.functions.worker.rest.api.v3.FunctionApiV3ResourceTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.pulsar.functions.worker.rest.api.v2.FunctionApiV2ResourceTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.pulsar.testclient.PerfClientUtilsTest created 12 new threads. There are now 22 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.pulsar.testclient.Oauth2PerformanceTransactionTest created 3 new threads. There are now 13 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.pulsar.testclient.PerformanceProducerTest created 21 new threads. There are now 31 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.zookeeper.LocalBookkeeperEnsembleTest created 41 new threads. There are now 50 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.broker.zookeeper.ZKReconnectTest created 3 new threads. There are now 50 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.broker.SameAuthParamsLookupAutoClusterFailoverTest created 2 new threads. There are now 52 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.broker.delayed.DelayedDeliveryTrackerFactoryTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.broker.EndToEndMetadataTest created 1 new threads. There are now 53 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.broker.resourcegroup.ResourceGroupConfigListenerTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.AdminRestTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.AdminApiTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.client.impl.ProduceWithMessageIdTest created 76 new threads. There are now 85 threads in total.
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.client.impl.ReaderTest created 8 new threads. There are now 17 threads in total.
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyStuckConnectionTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyIsAHttpProxyTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Pulsar IO - Elastic Search
Summary: Tests in class org.apache.pulsar.io.elasticsearch.ElasticSearchBWCTests created 6 new threads. There are now 15 threads in total.
CI - Unit - Pulsar IO - Elastic Search
Summary: Tests in class org.apache.pulsar.io.elasticsearch.v8.ElasticSearch8ClientTests created 10 new threads. There are now 25 threads in total.
CI - Unit - Pulsar IO - Elastic Search
Summary: Tests in class org.apache.pulsar.io.elasticsearch.v8.ElasticSearch8AuthTests created 11 new threads. There are now 35 threads in total.
CI - Unit - Pulsar IO - Elastic Search
Summary: Tests in class org.apache.pulsar.io.elasticsearch.v8.ElasticSearch8SinkTests created 1 new threads. There are now 34 threads in total.
CI - Unit - Pulsar IO - Elastic Search
Summary: Tests in class org.apache.pulsar.io.elasticsearch.v8.ElasticSearch8SinkRawDataTests created 3 new threads. There are now 37 threads in total.
CI - Unit - Pulsar IO - Elastic Search
Summary: Tests in class org.apache.pulsar.io.elasticsearch.ElasticSearchRawRecordTests created 96 new threads. There are now 133 threads in total.
CI - Unit - Pulsar IO - Elastic Search
Summary: Tests in class org.apache.pulsar.io.elasticsearch.v7.ElasticSearch7ClientTests created 3 new threads. There are now 136 threads in total.
CI - Unit - Pulsar IO - Elastic Search
Summary: Tests in class org.apache.pulsar.io.elasticsearch.opensearch.OpenSearchClientTests created 3 new threads. There are now 136 threads in total.
CI - Unit - Pulsar IO - Elastic Search
Summary: Tests in class org.apache.pulsar.io.elasticsearch.opensearch.OpenSearchClientSslTests created 18 new threads. There are now 151 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.http.HttpSinkTest created 78 new threads. There are now 87 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.kinesis.KinesisSinkTest created 9 new threads. There are now 19 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.hdfs3.sink.text.HdfsStringSinkTests created 1 new threads. There are now 10 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.hdfs3.sink.seq.HdfsTextSinkTests created 1 new threads. There are now 10 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.hdfs3.sink.seq.HdfsSequentialSinkTests created 1 new threads. There are now 10 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.flume.node.TestPollingZooKeeperConfigurationProvider created 4 new threads. There are now 13 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.flume.source.StringSourceTests created 20 new threads. There are now 29 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.flume.sink.StringSinkTests created 16 new threads. There are now 25 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.redis.sink.RedisSinkTest created 11 new threads. There are now 21 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.solr.SolrGenericRecordSinkTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Pulsar Metadata
Summary: Tests in class org.apache.pulsar.metadata.MetadataStoreTest created 8 new threads. There are now 18 threads in total.
CI - Unit - Pulsar Metadata
Summary: Tests in class org.apache.bookkeeper.replication.AuditorCheckAllLedgersTaskTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Pulsar Metadata
Summary: Tests in class org.apache.bookkeeper.replication.BookieAutoRecoveryTest created 14 new threads. There are now 24 threads in total.
CI - Unit - Pulsar Metadata
Summary: Tests in class org.apache.bookkeeper.replication.AuditorBookieTest created 28 new threads. There are now 38 threads in total.
CI - Unit - Pulsar Metadata
Summary: Tests in class org.apache.bookkeeper.replication.TestReplicationWorker created 43 new threads. There are now 53 threads in total.
CI - Unit - Pulsar Metadata
Summary: Tests in class org.apache.bookkeeper.replication.AuditorRollingRestartTest created 47 new threads. There are now 57 threads in total.
CI - Unit - Pulsar Metadata
Summary: Tests in class org.apache.bookkeeper.replication.AutoRecoveryMainTest created 18 new threads. There are now 28 threads in total.
CI - Unit - Pulsar Metadata
Summary: Tests in class org.apache.bookkeeper.replication.AuditorPeriodicCheckTest created 11 new threads. There are now 21 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.PulsarBrokerStarterTest created 4 new threads. There are now 13 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.service.BrokerServiceTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.service.OneWayReplicatorUsingGlobalZKTest created 371 new threads. There are now 380 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.service.persistent.PersistentTopicTest created 67 new threads. There are now 76 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.service.BacklogQuotaManagerTest created 167 new threads. There are now 177 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.service.persistent.TopicDuplicationTest created 66 new threads. There are now 79 threads in total.
Deprecation notice: v1, v2, and v3 of the artifact actions
The following artifacts were uploaded using a version of actions/upload-artifact that is scheduled for deprecation: "coverage_and_deps_unittest_BROKER_CLIENT_API.tar.zst", "coverage_and_deps_unittest_BROKER_CLIENT_IMPL.tar.zst", "coverage_and_deps_unittest_BROKER_GROUP_2.tar.zst", "coverage_and_deps_unittest_BROKER_GROUP_3.tar.zst", "coverage_and_deps_unittest_BROKER_GROUP_4.tar.zst", "coverage_and_deps_unittest_CLIENT.tar.zst", "coverage_and_deps_unittest_METADATA.tar.zst", "coverage_and_deps_unittest_OTHER.tar.zst", "coverage_and_deps_unittest_PROXY.tar.zst", "coverage_and_deps_unittest_PULSAR_IO.tar.zst", "coverage_and_deps_unittest_PULSAR_IO_ELASTIC.tar.zst", "coverage_and_deps_unittest_PULSAR_IO_KAFKA_CONNECT.tar.zst", "pulsar-maven-repository-binaries.tar.zst", "pulsar-server-distribution.tar.zst". Please update your workflow to use v4 of the artifact actions. Learn more: https://github.blog/changelog/2024-04-16-deprecation-notice-v3-of-the-artifact-actions/

Artifacts

Produced during runtime
Name Size
Unit-BROKER_GROUP_1-dumps
77.1 KB
Unit-BROKER_GROUP_1-surefire-reports
112 MB
coverage_and_deps_unittest_BROKER_CLIENT_API.tar.zst Expired
2.23 MB
coverage_and_deps_unittest_BROKER_CLIENT_IMPL.tar.zst Expired
2.25 MB
coverage_and_deps_unittest_BROKER_GROUP_2.tar.zst Expired
2.33 MB
coverage_and_deps_unittest_BROKER_GROUP_3.tar.zst Expired
2.25 MB
coverage_and_deps_unittest_BROKER_GROUP_4.tar.zst Expired
2.13 MB
coverage_and_deps_unittest_CLIENT.tar.zst Expired
656 KB
coverage_and_deps_unittest_METADATA.tar.zst Expired
261 KB
coverage_and_deps_unittest_OTHER.tar.zst Expired
10 MB
coverage_and_deps_unittest_PROXY.tar.zst Expired
208 KB
coverage_and_deps_unittest_PULSAR_IO.tar.zst Expired
359 KB
coverage_and_deps_unittest_PULSAR_IO_ELASTIC.tar.zst Expired
90.8 KB
coverage_and_deps_unittest_PULSAR_IO_KAFKA_CONNECT.tar.zst Expired
204 KB
pulsar-maven-repository-binaries.tar.zst Expired
317 MB
pulsar-server-distribution.tar.zst Expired
227 MB