Skip to content

[fix][broker] Fix data corruption issues when TLS is enabled and optimize TLS between Pulsar client and brokers #19632

[fix][broker] Fix data corruption issues when TLS is enabled and optimize TLS between Pulsar client and brokers

[fix][broker] Fix data corruption issues when TLS is enabled and optimize TLS between Pulsar client and brokers #19632

Triggered via pull request May 30, 2024 16:22
Status Failure
Total duration 53m 9s
Artifacts 54

pulsar-ci.yaml

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

Annotations

41 errors and 72 warnings
TransactionalReplicateSubscriptionTest.testReplicatedSubscribeAndSwitchToStandbyClusterWithTransaction: pulsar-broker/src/test/java/org/apache/pulsar/broker/service/TransactionalReplicateSubscriptionTest.java#L164
Assertion condition defined as a org.apache.pulsar.broker.service.TransactionalReplicateSubscriptionTest expected [20] but found [10] within 10 seconds.
CI - Unit - Brokers - Broker Group 2
Process completed with exit code 1.
CI - Integration - Shade on Java 17
Process completed with exit code 1.
SimpleProducerConsumerTest.testEncryptionFailure: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L445
Failed to receive message even after ConsumerCryptoFailureAction.CONSUME is set.
SimpleProducerConsumerTest.testEncryptionFailure: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L445
Failed to receive message even after ConsumerCryptoFailureAction.CONSUME is set.
CI - Integration - Shade on Java 11
Failed to CreateArtifact: Received non-retryable error: Failed request: (409) Conflict: an artifact with this name already exists on the workflow run
CI - Integration - Shade on Java 11
Process completed with exit code 1.
SimpleProducerConsumerTest.testEncryptionFailure: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L445
Failed to receive message even after ConsumerCryptoFailureAction.CONSUME is set.
CI - Integration - Shade on Java 21
Process completed with exit code 1.
CI - Integration - Shade on Java 21
Failed to CreateArtifact: Received non-retryable error: Failed request: (409) Conflict: an artifact with this name already exists on the workflow run
CI - Integration - Shade on Java 8
Failed to CreateArtifact: Received non-retryable error: Failed request: (409) Conflict: an artifact with this name already exists on the workflow run
CI - Integration - Shade on Java 8
Process completed with exit code 1.
SimpleProducerConsumerTest.testEncryptionFailure: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L445
Failed to receive message even after ConsumerCryptoFailureAction.CONSUME is set.
CI - Unit - Brokers - Broker Group 1
Process completed with exit code 1.
OneWayReplicatorUsingGlobalZKTest.testDeleteNonPartitionedTopic: pulsar-broker/src/test/java/org/apache/pulsar/broker/service/OneWayReplicatorUsingGlobalZKTest.java#L90
Cannot invoke "org.apache.pulsar.client.api.Message.getValue()" because the return value of "org.apache.pulsar.client.api.Consumer.receive(int, java.util.concurrent.TimeUnit)" is null
OneWayReplicatorUsingGlobalZKTest.cleanup: pulsar-broker/src/test/java/org/apache/pulsar/broker/service/OneWayReplicatorUsingGlobalZKTest.java#L40
org.apache.pulsar.client.admin.PulsarAdminException$ConflictException: Cannot delete non empty namespace
TransactionTest.transferNormalTest: pulsar-broker/src/test/java/org/apache/pulsar/broker/transaction/TransactionTest.java#L110
{"errorMsg":"The subscription reader-ba07ebeb7a of the topic persistent://public/default/__transaction_buffer_snapshot gets the last message id was failed Disconnected from server at pulsar-broker-1/172.19.0.7:6650","reqId":3442318544597452328, "remote":"localhost/127.0.0.1:32788", "local":"/127.0.0.1:33608"}
CI - Integration - Transaction
Process completed with exit code 1.
ExtensibleLoadManagerTest.testIsolationPolicy: tests/integration/src/test/java/org/apache/pulsar/tests/integration/loadbalance/ExtensibleLoadManagerTest.java#L363
Condition with org.apache.pulsar.tests.integration.loadbalance.ExtensibleLoadManagerTest was not fulfilled within 10 seconds.
CI - Integration - LoadBalance
Process completed with exit code 1.
ClientToolTest.testProduceConsumeThroughBrokers: tests/integration/src/test/java/org/apache/pulsar/tests/integration/cli/ClientToolTest.java#L48
Method org.apache.pulsar.tests.integration.cli.ClientToolTest.testProduceConsumeThroughBrokers() didn't finish within the time-out 300000
CI - Integration - Cli
Process completed with exit code 1.
DelayMessagingTest.delayMsgBlockTest: tests/integration/src/test/java/org/apache/pulsar/tests/integration/messaging/DelayMessagingTest.java#L89
Consumer can't receive message in double delayTimeSeconds time 10s expected object to not be null
CI - Integration - Messaging
Process completed with exit code 1.
CI - System - Tiered FileSystem
Process completed with exit code 1.
CI - System - Tiered JCloud
Process completed with exit code 1.
CI - System - Pulsar IO
Process completed with exit code 1.
CI Flaky - System - Plugin
Process completed with exit code 1.
PulsarFunctionsJavaProcessTest.testGenericObjectFunction: tests/integration/src/test/java/org/apache/pulsar/tests/integration/functions/java/PulsarFunctionsJavaProcessTest.java#L1
Assertion condition defined as a org.apache.pulsar.tests.integration.functions.PulsarFunctionsTest expected [true] but found [false] within 15 seconds.
CI - System - Pulsar Connectors - Process
Process completed with exit code 1.
CI - System - Function
Process completed with exit code 1.
CI - System - Pulsar Connectors - Thread
Process completed with exit code 1.
PulsarFunctionsJavaThreadTest.testGenericObjectRemoveFieldRecordFunction: tests/integration/src/test/java/org/apache/pulsar/tests/integration/functions/java/PulsarFunctionsJavaThreadTest.java#L1
Assertion condition defined as a org.apache.pulsar.tests.integration.functions.PulsarFunctionsTest expected [true] but found [false] within 15 seconds.
CI - System - Schema
Process completed with exit code 1.
PythonSchemaTest.testJavaPublishPythonConsume: tests/integration/src/test/java/org/apache/pulsar/tests/integration/python/PythonSchemaTest.java#L88
Method org.apache.pulsar.tests.integration.python.PythonSchemaTest.testJavaPublishPythonConsume() didn't finish within the time-out 300000
Pulsar CI checks completed
Process completed with exit code 1.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.compaction.StrategicCompactorTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.compaction.CompactorTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.compaction.ServiceUnitStateCompactionTest 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.service.TransactionalReplicateSubscriptionTest created 26 new threads. There are now 36 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.compaction.CompactedTopicTest created 79 new threads. There are now 88 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.broker.service.DeduplicationDisabledBrokerLevelTest created 60 new threads. There are now 70 threads in total.
CI - Integration - Shade on Java 17
No files were found with the provided path: tests/integration/target/container-logs. No artifacts will be uploaded.
CI - Integration - Shade on Java 11
No files were found with the provided path: tests/integration/target/container-logs. No artifacts will be uploaded.
CI - Integration - Shade on Java 21
No files were found with the provided path: tests/integration/target/container-logs. No artifacts will be uploaded.
CI - Integration - Shade on Java 8
No files were found with the provided path: tests/integration/target/container-logs. No artifacts will be uploaded.
CI - Unit - Pulsar IO - Elastic Search
Summary: Tests in class org.apache.pulsar.io.elasticsearch.v8.ElasticSearch8SinkRawDataTests 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.v8.ElasticSearch8AuthTests created 11 new threads. There are now 23 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 24 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 31 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 49 threads in total.
CI - Unit - Pulsar IO - Elastic Search
Summary: Tests in class org.apache.pulsar.io.elasticsearch.opensearch.OpenSearchClientTests created 2 new threads. There are now 51 threads in total.
CI - Unit - Pulsar IO - Elastic Search
Summary: Tests in class org.apache.pulsar.io.elasticsearch.v7.ElasticSearch7ClientTests created 2 new threads. There are now 53 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 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 1
Summary: Tests in class org.apache.pulsar.PulsarBrokerStarterTest created 9 new threads. There are now 18 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.zookeeper.MultiBrokerMetadataConsistencyTest 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.CompactionRetentionTest 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 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.BrokerServiceTest created 1 new threads. There are now 19 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.service.OneWayReplicatorUsingGlobalZKTest created 618 new threads. There are now 628 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.service.BrokerBookieIsolationTest created 70 new threads. There are now 80 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.service.ReplicatorTest created 608 new threads. There are now 627 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.transaction.pendingack.impl.MLPendingAckStoreTest created 6 new threads. There are now 635 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.service.BrokerBkEnsemblesTests created 130 new threads. There are now 140 threads in total.
CI - Unit - Pulsar Metadata
Summary: Tests in class org.apache.bookkeeper.replication.AuditorBookieTest created 27 new threads. There are now 37 threads in total.
CI - Unit - Pulsar Metadata
Summary: Tests in class org.apache.bookkeeper.replication.TestReplicationWorker created 24 new threads. There are now 34 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.AuditorCheckAllLedgersTaskTest created 1 new threads. There are now 11 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.BookieAutoRecoveryTest created 14 new threads. There are now 24 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 - Client Impl
Summary: Tests in class org.apache.pulsar.compaction.GetLastMessageIdCompactedTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.client.api.DeadLetterTopicTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.broker.service.ReplicatorGlobalNSTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.compaction.CompactionTest 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.ReaderTest created 8 new threads. There are now 18 threads in total.
CI - Unit - Brokers - Broker Group 4
Summary: Tests in class org.apache.pulsar.broker.service.ClusterMigrationTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.broker.service.persistent.PersistentDispatcherMultipleConsumersTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.websocket.proxy.ProxyPublishConsumeTlsTest 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.PulsarMultiListenersWithInternalListenerNameTest 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.ClientAuthenticationTlsTest created 1 new threads. There are now 10 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.bookie.rackawareness.BookieRackAffinityMappingTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.pulsar.opentelemetry.OpenTelemetryServiceTest 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.broker.authentication.AuthenticationProviderAthenzTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.pulsar.broker.authentication.ProxySaslAuthenticationTest created 2 new threads. There are now 12 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.pulsar.broker.authentication.SaslAuthenticateTest created 1 new threads. There are now 11 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.pulsar.packages.management.storage.bookkeeper.BookKeeperPackagesStorageTest created 2 new threads. There are now 12 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.bookkeeper.mledger.impl.ManagedLedgerTest created 10 new threads. There are now 20 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.AdminApiTenantTest 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.AdminResourceTest 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.AdminApiSchemaAutoUpdateTest 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.TopicMessageTTLTest 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 11 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.v3.AdminApiTransactionMultiBrokerTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.http.HttpSinkTest created 76 new threads. There are now 85 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.rabbitmq.sink.RabbitMQSinkTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Pulsar IO
Summary: Tests in class org.apache.pulsar.io.rabbitmq.source.RabbitMQSourceTest created 1 new threads. There are now 10 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.hdfs2.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.hdfs2.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.hdfs2.sink.seq.HdfsSequentialSinkTests created 1 new threads. There are now 10 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_inttest_METRICS.tar.zst", "coverage_and_deps_inttest_STANDALONE.tar.zst", "coverage_and_deps_unittest_BROKER_CLIENT_API.tar.zst", "coverage_and_deps_unittest_BROKER_CLIENT_IMPL.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-java-test-image.zst", "pulsar-maven-repository-binaries.tar.zst", "pulsar-server-distribution.tar.zst", "pulsar-test-latest-version-image.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
Integration-CLI-container-logs Expired
166 KB
Integration-CLI-surefire-reports Expired
184 KB
Integration-LOADBALANCE-container-logs Expired
1.55 MB
Integration-LOADBALANCE-surefire-reports Expired
1.7 MB
Integration-MESSAGING-container-logs Expired
575 KB
Integration-MESSAGING-surefire-reports Expired
394 KB
Integration-SHADE_RUN-surefire-reports Expired
78.1 KB
Integration-TRANSACTION-container-logs Expired
505 KB
Integration-TRANSACTION-surefire-reports Expired
714 KB
System-FUNCTION-container-logs Expired
538 KB
System-Function-surefire-reports Expired
176 KB
System-PLUGIN-container-logs Expired
388 KB
System-PULSAR_CONNECTORS_PROCESS-container-logs Expired
491 KB
System-PULSAR_CONNECTORS_THREAD-container-logs Expired
2.81 MB
System-PULSAR_IO-container-logs Expired
285 KB
System-Plugin-surefire-reports Expired
215 KB
System-Pulsar Connectors - Process-surefire-reports Expired
349 KB
System-Pulsar Connectors - Thread-surefire-reports Expired
3.65 MB
System-Pulsar IO-surefire-reports Expired
170 KB
System-SCHEMA-container-logs Expired
993 KB
System-Schema-surefire-reports Expired
2.5 MB
System-TIERED_FILESYSTEM-container-logs Expired
153 KB
System-TIERED_JCLOUD-container-logs Expired
165 KB
System-Tiered FileSystem-surefire-reports Expired
175 KB
System-Tiered JCloud-surefire-reports Expired
185 KB
Unit-BROKER_CLIENT_API-dumps Expired
15.6 KB
Unit-BROKER_CLIENT_IMPL-dumps Expired
19.6 KB
Unit-BROKER_GROUP_1-dumps Expired
177 KB
Unit-BROKER_GROUP_1-surefire-reports Expired
16.4 MB
Unit-BROKER_GROUP_2-dumps Expired
35.9 KB
Unit-BROKER_GROUP_2-surefire-reports Expired
11 MB
Unit-BROKER_GROUP_3-dumps Expired
22.8 KB
Unit-BROKER_GROUP_4-dumps Expired
3.83 KB
Unit-METADATA-dumps Expired
39.1 KB
Unit-OTHER-dumps Expired
37.4 KB
Unit-PULSAR_IO-dumps Expired
75.5 KB
Unit-PULSAR_IO_ELASTIC-dumps Expired
55.3 KB
coverage_and_deps_inttest_METRICS.tar.zst Expired
299 KB
coverage_and_deps_inttest_STANDALONE.tar.zst Expired
295 KB
coverage_and_deps_unittest_BROKER_CLIENT_API.tar.zst Expired
2.09 MB
coverage_and_deps_unittest_BROKER_CLIENT_IMPL.tar.zst Expired
2.11 MB
coverage_and_deps_unittest_BROKER_GROUP_3.tar.zst Expired
2.11 MB
coverage_and_deps_unittest_BROKER_GROUP_4.tar.zst Expired
2 MB
coverage_and_deps_unittest_CLIENT.tar.zst Expired
638 KB
coverage_and_deps_unittest_METADATA.tar.zst Expired
249 KB
coverage_and_deps_unittest_OTHER.tar.zst Expired
9.87 MB
coverage_and_deps_unittest_PROXY.tar.zst Expired
127 KB
coverage_and_deps_unittest_PULSAR_IO.tar.zst Expired
368 KB
coverage_and_deps_unittest_PULSAR_IO_ELASTIC.tar.zst Expired
90.5 KB
coverage_and_deps_unittest_PULSAR_IO_KAFKA_CONNECT.tar.zst Expired
173 KB
pulsar-java-test-image.zst Expired
284 MB
pulsar-maven-repository-binaries.tar.zst Expired
303 MB
pulsar-server-distribution.tar.zst Expired
214 MB
pulsar-test-latest-version-image.zst Expired
1.7 GB