Skip to content

[fix][client] Use dedicated executor for requests in BinaryProtoLookupService #21562

[fix][client] Use dedicated executor for requests in BinaryProtoLookupService

[fix][client] Use dedicated executor for requests in BinaryProtoLookupService #21562

Triggered via pull request October 14, 2024 11:12
Status Failure
Total duration 1h 16m 6s
Artifacts 29

pulsar-ci.yaml

on: pull_request
Preconditions
8s
Preconditions
Build and License check
9m 29s
Build and License check
Matrix: unit-tests
Build Pulsar docker image
24m 53s
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
3m 9s
CI - System - Upload Coverage
CI - Integration - Upload Coverage
2m 48s
CI - Integration - Upload Coverage
Build Pulsar on MacOS
8m 8s
Build Pulsar on MacOS
OWASP dependency check
0s
OWASP dependency check
Delete system test docker image artifact
8s
Delete system test docker image artifact
Delete integration test docker image artifact
10s
Delete integration test docker image artifact
Pulsar CI checks completed
4s
Pulsar CI checks completed
Fit to window
Zoom out
Zoom in

Annotations

5 errors and 105 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_-5509eea0-9abc-40ec-95be-9b515ff0dc4b-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_-5509eea0-9abc-40ec-95be-9b515ff0dc4b-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$28.operationFailed(ManagedCursorImpl.java:2940) at org.apache.bookkeeper.mledger.impl.ManagedCursorImpl$31.lambda$operationFailed$0(ManagedCursorImpl.java:3317) 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:3051) 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_-5509eea0-9abc-40ec-95be-9b515ff0dc4b-partition-1/pulsar.repl.r2
TransactionMetadataStoreServiceTest.testTimeoutTrackerMultiThreading: pulsar-broker/src/test/java/org/apache/pulsar/broker/service/TransactionMetadataStoreServiceTest.java#L237
Condition org.apache.pulsar.broker.service.TransactionMetadataStoreServiceTest$$Lambda/0x00007fc3c87cc230 was not fulfilled within 10 seconds.
Build Pulsar on MacOS
Process completed with exit code 1.
Pulsar CI checks completed
Process completed with exit code 1.
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyAuthenticationTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyAuthenticatedProducerConsumerTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyWithoutServiceDiscoveryTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyStuckConnectionTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.UnauthedAdminProxyHandlerTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyWithExtensibleLoadManagerTest created 2 new threads. There are now 12 threads in total.
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyWithJwtAuthorizationTest created 3 new threads. There are now 15 threads in total.
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyRolesEnforcementTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyForwardAuthDataTest created 1 new threads. There are now 12 threads in total.
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyIsAHttpProxyTest created 1 new threads. There are now 16 threads in total.
CI - Unit - Brokers - Broker Group 4
Summary: Tests in class org.apache.pulsar.broker.service.ClusterMigrationTest created 88 new threads. There are now 97 threads in total.
CI - Unit - Pulsar IO - Kafka Connect Adaptor
Summary: Tests in class org.apache.pulsar.io.kafka.connect.KafkaConnectSourceErrTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Pulsar IO - Kafka Connect Adaptor
Summary: Tests in class org.apache.pulsar.io.kafka.connect.KafkaConnectSourceErrRecTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Pulsar IO - Kafka Connect Adaptor
Summary: Tests in class org.apache.pulsar.io.kafka.connect.KafkaConnectSourceTest created 2 new threads. There are now 12 threads in total.
CI - Unit - Pulsar IO - Kafka Connect Adaptor
Summary: Tests in class org.apache.pulsar.io.kafka.connect.PulsarOffsetBackingStoreTest created 5 new threads. There are now 15 threads in total.
CI - Unit - Pulsar IO - Kafka Connect Adaptor
Summary: Tests in class org.apache.pulsar.io.kafka.connect.KafkaConnectSinkTest created 32 new threads. There are now 43 threads in total.
CI - Unit - Pulsar IO - Kafka Connect Adaptor
Summary: Tests in class org.apache.pulsar.io.debezium.PulsarDatabaseHistoryTest created 5 new threads. There are now 15 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 1 new threads. There are now 134 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 - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.ConsumerRedeliveryTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.metrics.ClientMetricsTest created 3 new threads. There are now 12 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.MessageListenerExecutorTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.MaxProducerTest created 1 new threads. There are now 13 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.ClientDeduplicationTest created 6 new threads. There are now 19 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.SimpleTypedProducerConsumerTest created 5 new threads. There are now 15 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.OrphanPersistentTopicTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.ProducerCleanupTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.TokenExpirationProduceConsumerTest created 2 new threads. There are now 21 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.ProducerCreationTest created 9 new threads. There are now 24 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.http.HttpSinkTest created 80 new threads. There are now 89 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 47 new threads. There are now 57 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 19 new threads. There are now 29 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 2
Summary: Tests in class org.apache.pulsar.io.PulsarSourceE2ETest created 4 new threads. There are now 13 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.io.PulsarBatchSourceE2ETest created 3 new threads. There are now 12 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 54 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.client.impl.AutoScaledReceiverQueueSizeTest created 1 new threads. There are now 13 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.client.impl.DynamicReceiverQueueSizeTest created 1 new threads. There are now 55 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.io.PulsarSinkE2ETest created 7 new threads. There are now 16 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.client.impl.MessageParserTest created 1 new threads. There are now 14 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.client.impl.ClientWithSocks5ProxyTest created 5 new threads. There are now 57 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.client.impl.TransactionClientConnectTest created 8 new threads. There are now 22 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.client.impl.MessagePublishThrottlingTest created 5 new threads. There are now 21 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.client.impl.LookupServiceTest 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.AnalyzeBacklogSubscriptionTest created 3 new threads. There are now 12 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.AdminTest 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.NamespaceAuthZTest created 1 new threads. There are now 13 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.AdminApiHealthCheckTest created 4 new threads. There are now 13 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.TopicPoliciesWithBrokerRestartTest created 2 new threads. There are now 12 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.TopicAuthZTest created 1 new threads. There are now 14 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.AdminApiSchemaValidationEnforcedTest created 5 new threads. There are now 19 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.AdminApiMaxUnackedMessagesTest created 2 new threads. There are now 21 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.CreateSubscriptionTest created 18 new threads. There are now 31 threads in total.
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.client.impl.HierarchyTopicAutoCreationTest created 3 new threads. There are now 12 threads in total.
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.client.impl.CompactionReaderImplTest 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.AutoCloseUselessClientConMultiTopicTest 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.TableViewTest 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.ConsumeBaseExceptionTest created 2 new threads. There are now 12 threads in total.
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.client.impl.TopicPublishThrottlingInitTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.client.impl.ConsumerConfigurationTest created 2 new threads. There are now 13 threads in total.
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.client.impl.ProducerCloseTest created 6 new threads. There are now 18 threads in total.
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.client.impl.ProducerMemoryLimitTest created 6 new threads. There are now 16 threads in total.
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.client.impl.KeyStoreTlsProducerConsumerTestWithoutAuthTest created 4 new threads. There are now 16 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.client.api.PatternMultiTopicsConsumerTest created 3 new threads. There are now 12 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.compaction.CompactionRetentionTest created 5 new threads. There are now 14 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.client.api.MultiTopicsConsumerTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.compaction.StrategicCompactionRetentionTest created 5 new threads. There are now 18 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.stats.TransactionBatchWriterMetricsTest created 1 new threads. There are now 13 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.stats.SubscriptionStatsTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.namespace.NamespaceUnloadingTest created 2 new threads. There are now 15 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.namespace.OwnerShipCacheForCurrentServerTest created 4 new threads. There are now 19 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.stats.AuthenticatedConsumerStatsTest created 10 new threads. There are now 24 threads in total.
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 4 new threads. There are now 14 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.pulsar.testclient.PerformanceProducerTest created 26 new threads. There are now 36 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
Jacoco-coverage-report-inttests Expired
25.5 MB
Jacoco-coverage-report-systests Expired
25.7 MB
Unit-BROKER_CLIENT_API-dumps
206 KB
Unit-BROKER_CLIENT_IMPL-dumps
311 KB
Unit-BROKER_GROUP_1-dumps
580 KB
Unit-BROKER_GROUP_1-surefire-reports
125 MB
Unit-BROKER_GROUP_2-dumps
510 KB
Unit-BROKER_GROUP_3-dumps
212 KB
Unit-BROKER_GROUP_4-dumps
10.1 KB
Unit-METADATA-dumps
47.2 KB
Unit-OTHER-dumps
72.5 KB
Unit-PROXY-dumps
42.2 KB
Unit-PULSAR_IO-dumps
60.8 KB
Unit-PULSAR_IO_ELASTIC-dumps
72.8 KB
Unit-PULSAR_IO_KAFKA_CONNECT-dumps
27 KB
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
657 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
207 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