Skip to content

[fix] [broker] response not-found error if topic does not exist when calling getPartitionedTopicMetadata #19777

[fix] [broker] response not-found error if topic does not exist when calling getPartitionedTopicMetadata

[fix] [broker] response not-found error if topic does not exist when calling getPartitionedTopicMetadata #19777

Triggered via pull request June 6, 2024 20:21
Status Failure
Total duration 1h 15m 35s
Artifacts 27

pulsar-ci.yaml

on: pull_request
Preconditions
8s
Preconditions
Build and License check
9m 9s
Build and License check
Matrix: unit-tests
Build Pulsar docker image
21m 1s
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 2s
CI - System - Upload Coverage
CI - Integration - Upload Coverage
1m 38s
CI - Integration - Upload Coverage
Build Pulsar on MacOS
13m 18s
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
7s
Delete integration test docker image artifact
Pulsar CI checks completed
3s
Pulsar CI checks completed
Fit to window
Zoom out
Zoom in

Annotations

13 errors and 63 warnings
TopicsTest.testLookUpWithException: pulsar-broker/src/test/java/org/apache/pulsar/broker/admin/TopicsTest.java#L377
expected [Can't find owner of given topic.] but found [Fail to publish message: Topic persistent://my-tenant/my-namespace/my-topic not found]
CI - Unit - Brokers - Broker Group 2
Process completed with exit code 1.
CI - Unit - Other
Process completed with exit code 1.
CI - Unit - Brokers - Client Api
Process completed with exit code 1.
CI - Unit - Pulsar Metadata
Process completed with exit code 1.
CI - Unit - Brokers - Broker Group 3
Process completed with exit code 1.
NamespaceAuthZTest.testMaxConsumersPerSubscription: pulsar-broker/src/test/java/org/apache/pulsar/broker/admin/NamespaceAuthZTest.java#L1618
Unfinished stubbing detected here: -> at org.apache.pulsar.broker.admin.NamespaceAuthZTest.setAuthorizationPolicyOperationChecker(NamespaceAuthZTest.java:173) 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 - Broker Group 1
Process completed with exit code 1.
Pulsar CI checks completed
Process completed with exit code 1.
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.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.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.compaction.CompactedTopicTest 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.stats.TransactionMetricsTest created 77 new threads. There are now 87 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.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 - 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 - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.TlsProducerConsumerTest created 48 new threads. There are now 58 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.SubscriptionPauseOnAckStatPersistTest created 76 new threads. There are now 86 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.SimpleProducerConsumerTest created 96 new threads. There are now 106 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 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 9 new threads. There are now 33 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 51 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 - 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 23 new threads. There are now 33 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 15 new threads. There are now 25 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 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 138 new threads. There are now 148 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.TopicPoliciesTest created 66 new threads. There are now 76 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.AdminApi2Test created 105 new threads. There are now 115 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 - 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.
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 11 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.service.ReplicatedSubscriptionWithTransactionTest created 7 new threads. There are now 17 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.intercept.BrokerInterceptorTest created 61 new threads. There are now 79 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.broker.transaction.buffer.TransactionStablePositionTest created 87 new threads. There are now 97 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_IMPL.tar.zst", "coverage_and_deps_unittest_BROKER_GROUP_4.tar.zst", "coverage_and_deps_unittest_CLIENT.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
18.7 MB
Jacoco-coverage-report-systests Expired
19 MB
Unit-BROKER_CLIENT_API-dumps Expired
45 KB
Unit-BROKER_CLIENT_API-surefire-reports Expired
13.9 MB
Unit-BROKER_CLIENT_IMPL-dumps Expired
19.5 KB
Unit-BROKER_GROUP_1-dumps Expired
45.2 KB
Unit-BROKER_GROUP_1-surefire-reports Expired
30.5 MB
Unit-BROKER_GROUP_2-dumps Expired
25.3 KB
Unit-BROKER_GROUP_2-surefire-reports Expired
11.7 MB
Unit-BROKER_GROUP_3-dumps Expired
51.6 KB
Unit-BROKER_GROUP_3-surefire-reports Expired
19.8 MB
Unit-BROKER_GROUP_4-dumps Expired
3.82 KB
Unit-METADATA-dumps Expired
39.1 KB
Unit-METADATA-surefire-reports Expired
2.64 MB
Unit-OTHER-dumps Expired
13.8 KB
Unit-OTHER-surefire-reports Expired
2.03 MB
Unit-PULSAR_IO-dumps Expired
75.2 KB
Unit-PULSAR_IO_ELASTIC-dumps Expired
55.3 KB
coverage_and_deps_unittest_BROKER_CLIENT_IMPL.tar.zst Expired
2.11 MB
coverage_and_deps_unittest_BROKER_GROUP_4.tar.zst Expired
2.01 MB
coverage_and_deps_unittest_CLIENT.tar.zst Expired
638 KB
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.4 KB
coverage_and_deps_unittest_PULSAR_IO_KAFKA_CONNECT.tar.zst Expired
173 KB
pulsar-maven-repository-binaries.tar.zst Expired
288 MB
pulsar-server-distribution.tar.zst Expired
204 MB