[fix][meta] Fix ephemeral handling of ZK nodes and fix MockZooKeeper ephemeral and ZK stat handling #22981
pulsar-ci.yaml
on: pull_request
Preconditions
8s
Matrix: unit-tests
Matrix: Build Pulsar java-test-image docker image
CI - Unit - Upload Coverage
0s
Run CodeQL Analysis
0s
Matrix: system-tests
Matrix: flaky-system-tests
Matrix: integration-tests
Delete system test docker image artifact
0s
Delete integration test docker image artifact
0s
Pulsar CI checks completed
7s
Annotations
20 errors and 60 warnings
LedgerManagerIteratorTest.checkConcurrentModifications:
pulsar-metadata/src/test/java/org/apache/pulsar/metadata/bookkeeper/LedgerManagerIteratorTest.java#L459
Method org.apache.pulsar.metadata.bookkeeper.LedgerManagerIteratorTest.checkConcurrentModifications() didn't finish within the time-out 30000
|
CI - Unit - Pulsar Metadata
Process completed with exit code 1.
|
CI - Unit - Brokers - Broker Group 3
Process completed with exit code 1.
|
AdminApiOffloadTest.testOffloadV2:
pulsar-broker/src/test/java/org/apache/pulsar/broker/admin/AdminApiOffloadTest.java#L202
expected [ERROR] but found [RUNNING]
|
CI - Unit - Other
Process completed with exit code 1.
|
FunctionAssignmentTailerTest.testErrorNotifier:
pulsar-functions/worker/src/test/java/org/apache/pulsar/functions/worker/FunctionAssignmentTailerTest.java#L164
Unfinished stubbing detected here:
-> at org.apache.pulsar.functions.worker.FunctionAssignmentTailerTest.testErrorNotifier(FunctionAssignmentTailerTest.java:164)
E.g. thenReturn() may be missing.
Examples of correct stubbing:
when(mock.isOk()).thenReturn(true);
when(mock.isOk()).thenThrow(exception);
doThrow(exception).when(mock).someVoidMethod();
Hints:
1. missing thenReturn()
2. you are trying to stub a final method, which is not supported
3. you are stubbing the behaviour of another mock inside before 'thenReturn' instruction is completed
|
|
CI - Unit - Brokers - Client Api
Process completed with exit code 1.
|
CI Flaky - System - Plugin
Process completed with exit code 1.
|
CI - Integration - Messaging
Canceling since a higher priority waiting request for 'Pulsar CI-refs/pull/23988/merge-pull_request' exists
|
CI - Integration - Messaging
The operation was canceled.
|
CI - Integration - Cli
Canceling since a higher priority waiting request for 'Pulsar CI-refs/pull/23988/merge-pull_request' exists
|
CI - Integration - Cli
The operation was canceled.
|
CI - System - Pulsar IO
Canceling since a higher priority waiting request for 'Pulsar CI-refs/pull/23988/merge-pull_request' exists
|
CI - System - Pulsar IO
The operation was canceled.
|
CI - System - Pulsar Connectors - Thread
Canceling since a higher priority waiting request for 'Pulsar CI-refs/pull/23988/merge-pull_request' exists
|
CI - System - Pulsar Connectors - Thread
The operation was canceled.
|
CI - System - Pulsar Connectors - Process
Canceling since a higher priority waiting request for 'Pulsar CI-refs/pull/23988/merge-pull_request' exists
|
CI - System - Pulsar Connectors - Process
The operation was canceled.
|
Pulsar CI checks completed
Process completed with exit code 1.
|
Build Pulsar java-test-image docker image (linux/amd64)
Failed to save: Failed to CreateCacheEntry: Received non-retryable error: Failed request: (409) Conflict: cache entry with the same key, version, and scope already exists
|
CI - Unit - Pulsar Metadata
Summary: Tests in class org.apache.pulsar.metadata.bookkeeper.LedgerUnderreplicationManagerTest created 23 new threads. There are now 33 threads in total.
|
Build Pulsar java-test-image docker image (linux/arm64)
Failed to save: Failed to CreateCacheEntry: Received non-retryable error: Failed request: (409) Conflict: cache entry with the same key, version, and scope already exists
|
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.AdminApiTlsAuthTest 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.TenantEndpointsAuthorizationTest created 8 new threads. There are now 17 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.AdminApi2Test created 107 new threads. There are now 116 threads in total.
|
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.TopicPoliciesWithBrokerRestartTest created 77 new threads. There are now 86 threads in total.
|
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.UnauthedAdminProxyHandlerTest 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 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 - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyDisableZeroCopyTest created 1010 new threads. There are now 1019 threads in total.
|
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyTest created 1000 new threads. There are now 1009 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.FileSystemOffloaderLocalFileTest created 3 new threads. There are now 14 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.FunctionAssignmentTailerTest created 2 new threads. There are now 12 threads in total.
|
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.AuthenticatedProducerConsumerTest created 67 new threads. There are now 76 threads in total.
|
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.SimpleProducerConsumerTest created 61 new threads. There are now 70 threads in total.
|
CI - Unit - Brokers - Broker Group 4
Summary: Tests in class org.apache.pulsar.broker.service.ClusterMigrationTest created 2 new threads. There are now 11 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 12 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 29 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 33 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 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 36 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 37 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 48 threads in total.
|
CI - Unit - Pulsar IO - Elastic Search
Summary: Tests in class org.apache.pulsar.io.elasticsearch.v8.ElasticSearch8ClientTests created 7 new threads. There are now 55 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 151 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.resourcegroup.ResourceGroupConfigListenerTest 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.zookeeper.ZKReconnectTest created 3 new threads. There are now 12 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 11 threads in total.
|
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.broker.qos.AsyncTokenBucketTest created 1 new threads. There are now 12 threads in total.
|
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.broker.SameAuthParamsLookupAutoClusterFailoverTest created 5 new threads. There are now 17 threads in total.
|
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.client.impl.ProduceWithMessageIdTest created 70 new threads. There are now 79 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 - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.client.impl.BrokerClientIntegrationTest created 1 new threads. There are now 80 threads in total.
|
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.http.HttpSinkTest created 81 new threads. There are now 90 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.HdfsSequentialSinkTests 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 2 new threads. There are now 11 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 Flaky - System - Plugin
No files were found with the provided path: tests/integration/target/container-logs. No artifacts will be uploaded.
|
CI Flaky - System - Plugin
No files were found with the provided path: surefire-reports. No artifacts will be uploaded.
|
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 2 new threads. There are now 11 threads in total.
|
CI - Integration - Messaging
No files were found with the provided path: surefire-reports. No artifacts will be uploaded.
|
CI - Integration - Cli
No files were found with the provided path: surefire-reports. No artifacts will be uploaded.
|
CI - System - Pulsar IO
No files were found with the provided path: surefire-reports. No artifacts will be uploaded.
|
CI - System - Pulsar Connectors - Thread
No files were found with the provided path: surefire-reports. No artifacts will be uploaded.
|
CI - System - Pulsar Connectors - Process
No files were found with the provided path: surefire-reports. No artifacts will be uploaded.
|
Artifacts
Produced during runtime
Name | Size | |
---|---|---|
Integration-CLI-container-logs
|
1.08 MB |
|
Integration-MESSAGING-container-logs
|
926 KB |
|
System-PULSAR_CONNECTORS_PROCESS-container-logs
|
134 KB |
|
System-PULSAR_CONNECTORS_THREAD-container-logs
|
114 KB |
|
System-PULSAR_IO-container-logs
|
291 KB |
|
Unit-BROKER_CLIENT_API-dumps
|
18.7 KB |
|
Unit-BROKER_CLIENT_API-surefire-reports
|
16.8 MB |
|
Unit-BROKER_CLIENT_IMPL-dumps
|
22.7 KB |
|
Unit-BROKER_GROUP_1-dumps
|
8.42 KB |
|
Unit-BROKER_GROUP_2-dumps
|
28.3 KB |
|
Unit-BROKER_GROUP_3-dumps
|
35.3 KB |
|
Unit-BROKER_GROUP_3-surefire-reports
|
18.5 MB |
|
Unit-BROKER_GROUP_4-dumps
|
4.19 KB |
|
Unit-METADATA-dumps
|
6.98 KB |
|
Unit-METADATA-surefire-reports
|
3.46 MB |
|
Unit-OTHER-dumps
|
31.6 KB |
|
Unit-OTHER-surefire-reports
|
3.59 MB |
|
Unit-PROXY-dumps
|
118 KB |
|
Unit-PULSAR_IO-dumps
|
60.3 KB |
|
Unit-PULSAR_IO_ELASTIC-dumps
|
59 KB |
|
coverage_and_deps_inttest_METRICS.tar.zst
Expired
|
303 KB |
|
coverage_and_deps_inttest_STANDALONE.tar.zst
Expired
|
298 KB |
|
coverage_and_deps_inttest_TRANSACTION.tar.zst
Expired
|
307 KB |
|
coverage_and_deps_inttest_UPGRADE.tar.zst
Expired
|
301 KB |
|
coverage_and_deps_systest_FUNCTION.tar.zst
Expired
|
308 KB |
|
coverage_and_deps_systest_SCHEMA.tar.zst
Expired
|
309 KB |
|
coverage_and_deps_systest_TIERED_FILESYSTEM.tar.zst
Expired
|
132 MB |
|
coverage_and_deps_systest_TIERED_JCLOUD.tar.zst
Expired
|
302 KB |
|
coverage_and_deps_unittest_BROKER_CLIENT_IMPL.tar.zst
Expired
|
2.29 MB |
|
coverage_and_deps_unittest_BROKER_GROUP_1.tar.zst
Expired
|
2.53 MB |
|
coverage_and_deps_unittest_BROKER_GROUP_2.tar.zst
Expired
|
2.39 MB |
|
coverage_and_deps_unittest_BROKER_GROUP_4.tar.zst
Expired
|
2.18 MB |
|
coverage_and_deps_unittest_CLIENT.tar.zst
Expired
|
666 KB |
|
coverage_and_deps_unittest_PROXY.tar.zst
Expired
|
211 KB |
|
coverage_and_deps_unittest_PULSAR_IO.tar.zst
Expired
|
363 KB |
|
coverage_and_deps_unittest_PULSAR_IO_ELASTIC.tar.zst
Expired
|
91.4 KB |
|
coverage_and_deps_unittest_PULSAR_IO_KAFKA_CONNECT.tar.zst
Expired
|
206 KB |
|
pulsar-java-test-image.zst
Expired
|
289 MB |
|
pulsar-maven-repository-binaries.tar.zst
Expired
|
319 MB |
|
pulsar-server-distribution.tar.zst
Expired
|
228 MB |
|
pulsar-test-latest-version-image.zst
Expired
|
3.19 GB |
|