Skip to content

lh jetty 12

lh jetty 12 #1631

Triggered via pull request May 13, 2024 12:09
Status Failure
Total duration 1h 18m 44s
Artifacts 39

pulsar-ci.yaml

on: pull_request
Preconditions
8s
Preconditions
Build and License check
10m 54s
Build and License check
Matrix: unit-tests
Build Pulsar docker image
16m 14s
Build Pulsar docker image
Build Pulsar java-test-image docker image
5m 51s
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
4s
Pulsar CI checks completed
Fit to window
Zoom out
Zoom in

Annotations

65 errors and 65 warnings
CI - Unit - Brokers - Broker Group 1
Process completed with exit code 1.
BrokerAdditionalServletTest.test: pulsar-broker/src/test/java/org/apache/pulsar/broker/BrokerAdditionalServletTest.java#L125
expected [value - 253576916] but found [<html> <head> <meta http-equiv="Content-Type" content="text/html;charset=ISO-8859-1"/> <title>Error 500 java.lang.ClassCastException: class org.eclipse.jetty.ee8.nested.Request cannot be cast to class org.eclipse.jetty.server.Request (org.eclipse.jetty.ee8.nested.Request and org.eclipse.jetty.server.Request are in unnamed module of loader &apos;app&apos;)</title> </head> <body><h2>HTTP ERROR 500 java.lang.ClassCastException: class org.eclipse.jetty.ee8.nested.Request cannot be cast to class org.eclipse.jetty.server.Request (org.eclipse.jetty.ee8.nested.Request and org.eclipse.jetty.server.Request are in unnamed module of loader &apos;app&apos;)</h2> <table> <tr><th>URI:</th><td>/additional/servlet/</td></tr> <tr><th>STATUS:</th><td>500</td></tr> <tr><th>MESSAGE:</th><td>java.lang.ClassCastException: class org.eclipse.jetty.ee8.nested.Request cannot be cast to class org.eclipse.jetty.server.Request (org.eclipse.jetty.ee8.nested.Request and org.eclipse.jetty.server.Request are in unnamed module of loader &apos;app&apos;)</td></tr> <tr><th>SERVLET:</th><td>org.apache.pulsar.broker.BrokerAdditionalServletTest$OrdinaryServlet-4e301f93</td></tr> <tr><th>CAUSED BY:</th><td>java.lang.ClassCastException: class org.eclipse.jetty.ee8.nested.Request cannot be cast to class org.eclipse.jetty.server.Request (org.eclipse.jetty.ee8.nested.Request and org.eclipse.jetty.server.Request are in unnamed module of loader &apos;app&apos;)</td></tr> </table> <h3>Caused by:</h3><pre>java.lang.ClassCastException: class org.eclipse.jetty.ee8.nested.Request cannot be cast to class org.eclipse.jetty.server.Request (org.eclipse.jetty.ee8.nested.Request and org.eclipse.jetty.server.Request are in unnamed module of loader &apos;app&apos;) at org.apache.pulsar.broker.BrokerAdditionalServletTest$OrdinaryServlet.service(BrokerAdditionalServletTest.java:148) at org.eclipse.jetty.ee8.servlet.ServletHolder.handle(ServletHolder.java:640) at org.eclipse.jetty.ee8.servlet.ServletHandler$ChainEnd.doFilter(ServletHandler.java:1374) at org.eclipse.jetty.ee8.servlets.QoSFilter.doFilter(QoSFilter.java:190) at org.eclipse.jetty.ee8.servlet.FilterHolder.doFilter(FilterHolder.java:171) at org.eclipse.jetty.ee8.servlet.ServletHandler$Chain.doFilter(ServletHandler.java:1348) at org.eclipse.jetty.ee8.servlet.ServletHandler.doHandle(ServletHandler.java:454) at org.eclipse.jetty.ee8.nested.ScopedHandler.nextHandle(ScopedHandler.java:181) at org.eclipse.jetty.ee8.nested.SessionHandler.doHandle(SessionHandler.java:404) at org.eclipse.jetty.ee8.nested.ScopedHandler.nextHandle(ScopedHandler.java:181) at org.eclipse.jetty.ee8.nested.ContextHandler.doHandle(ContextHandler.java:878) at org.eclipse.jetty.ee8.nested.ScopedHandler.nextScope(ScopedHandler.java:152) at org.eclipse.jetty.ee8.servlet.ServletHandler.doScope(ServletHandler.java:423) at org.eclipse.jetty.ee8.nested.ScopedHandler.nextScope(ScopedHandler.java:150) at org.eclipse.jetty.ee8.nested.SessionHandler.doScope(SessionHandler.java:399) at org.eclipse.jetty.ee8.nested.ScopedHandler.nextScope(ScopedHandler.java:150) at org.eclipse.jetty.ee8.nested.ContextHandler.doScope(ContextHandler.java:823) at org.eclipse.jetty.ee8.nested.ScopedHandler.handle(ScopedHandler.java:117) at org.eclipse.jetty.ee8.nested.ContextHandler.handle(ContextHandler.java:1421) at org.eclipse.jetty.ee8.nested.HttpChannel$RequestDispatchable.dispatch(HttpChannel.java:1293) at org.eclipse.jetty.ee8.nested.HttpChannel.dispatch(HttpChannel.java:623) at org.eclipse.jetty.ee8.nested.HttpChannel.handle(HttpChannel.java:455) at org.eclipse.jetty.ee8.nested.ContextHandler$CoreContextHandler$CoreToNestedHandler.handle(ContextHandler.java:2257) at org.eclipse.jetty.server.handler.ContextHandler.handle(ContextHandler.java:851) at org.eclipse.jetty.server.handler.ContextHandlerCollection.handle(ContextHandlerCollection.java:181) at org.eclipse.jetty.server.handler.gzip.GzipHandler.handle(GzipHandler.java:597) at org.eclipse.jetty.server.Handler$Sequence.handle(Handler.java:805) at org.eclipse.jett
CI - Unit - Other
Process completed with exit code 1.
CI - Unit - Proxy
Process completed with exit code 1.
ProxyServiceTlsStarterTest.testProduceAndConsumeMessageWithWebsocket: pulsar-proxy/src/test/java/org/apache/pulsar/proxy/server/ProxyServiceTlsStarterTest.java#L117
Unrecognized WebSocket endpoint: org.apache.pulsar.proxy.server.ProxyServiceTlsStarterTest$MyWebSocket
CI - Unit - Brokers - Broker Group 3
Process completed with exit code 1.
TlsHostVerificationTest.testTlsHostVerificationDisabledAdminClient: pulsar-broker/src/test/java/org/apache/pulsar/client/api/TlsHostVerificationTest.java#L88
HTTP 400 { "message":"Invalid SNI", "url":"https://127.0.0.2:43629/admin/v2/tenants", "status":"400" }
CI - Unit - Brokers - Client Api
Process completed with exit code 1.
Build Pulsar docker image
Process completed with exit code 1.
PulsarFunctionE2ETest.testFunctionAutomaticSubCleanup: pulsar-broker/src/test/java/org/apache/pulsar/io/PulsarFunctionE2ETest.java#L926
Method org.apache.pulsar.io.PulsarFunctionE2ETest.testFunctionAutomaticSubCleanup() didn't finish within the time-out 20000
TlsWithECCertificateFileTest.suitSetup: pulsar-broker/src/test/java/org/apache/pulsar/security/tls/ec/TlsWithECCertificateFileTest.java#L49
HTTP 400 { "message":"Invalid SNI", "url":"https://localhost:33729/admin/v2/clusters", "status":"400" }
TlsWithECKeyStoreTest.suitSetup: pulsar-broker/src/test/java/org/apache/pulsar/security/tls/ec/TlsWithECKeyStoreTest.java#L51
HTTP 400 { "message":"Invalid SNI", "url":"https://localhost:39997/admin/v2/clusters", "status":"400" }
CI - Unit - Brokers - Broker Group 2
Process completed with exit code 1.
SmokeTest.setup: tests/bc_2_0_0/src/test/java/org/apache/pulsar/tests/integration/SmokeTest.java#L46
Container startup failed for image apachepulsar/java-test-image:latest
CI - Integration - Backwards Compatibility
Process completed with exit code 1.
TransactionTest.setupBeforeClass: pulsar-broker/src/test/java/org/apache/pulsar/broker/transaction/TransactionTest.java#L58
Container startup failed for image apachepulsar/java-test-image:latest
CI - Integration - Transaction
Process completed with exit code 1.
CI - Integration - Metrics
Process completed with exit code 1.
SmokeTest.stateCheck: tests/bc_2_0_0/src/test/java/org/apache/pulsar/tests/integration/SmokeTest.java#L1
Container startup failed for image apachepulsar/java-test-image:latest
SmokeTest.setup: tests/bc_2_0_0/src/test/java/org/apache/pulsar/tests/integration/SmokeTest.java#L1
Container startup failed for image apachepulsar/java-test-image:latest
CI - Integration - Standalone
Process completed with exit code 1.
CI - Integration - Shade on Java 11
Process completed with exit code 1.
SimpleProducerConsumerTest.stateCheck: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SimpleProducerConsumerTest.stateCheck: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SimpleProducerConsumerTest.stateCheck: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SimpleProducerConsumerTest.setup: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SmokeTest.setup: tests/bc_2_0_0/src/test/java/org/apache/pulsar/tests/integration/SmokeTest.java#L50
Container startup failed for image apachepulsar/java-test-image:latest
SmokeTest.stateCheck: tests/bc_2_0_0/src/test/java/org/apache/pulsar/tests/integration/SmokeTest.java#L50
Container startup failed for image apachepulsar/java-test-image:latest
CI - Integration - Shade on Java 17
Process completed with exit code 1.
SimpleProducerConsumerTest.setup: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SimpleProducerConsumerTest.stateCheck: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SimpleProducerConsumerTest.stateCheck: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SimpleProducerConsumerTest.stateCheck: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SmokeTest.setup: tests/bc_2_0_0/src/test/java/org/apache/pulsar/tests/integration/SmokeTest.java#L50
Container startup failed for image apachepulsar/java-test-image:latest
SmokeTest.stateCheck: tests/bc_2_0_0/src/test/java/org/apache/pulsar/tests/integration/SmokeTest.java#L50
Container startup failed for image apachepulsar/java-test-image:latest
CI - Integration - Shade on Java 17
Failed to CreateArtifact: Received non-retryable error: Failed request: (409) Conflict: an artifact with this name already exists on the workflow run
SimpleProducerConsumerTest.setup: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SimpleProducerConsumerTest.stateCheck: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SimpleProducerConsumerTest.stateCheck: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SimpleProducerConsumerTest.stateCheck: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SmokeTest.setup: tests/bc_2_0_0/src/test/java/org/apache/pulsar/tests/integration/SmokeTest.java#L50
Container startup failed for image apachepulsar/java-test-image:latest
SmokeTest.stateCheck: tests/bc_2_0_0/src/test/java/org/apache/pulsar/tests/integration/SmokeTest.java#L50
Container startup failed for image apachepulsar/java-test-image:latest
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 21
Process completed with exit code 1.
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.stateCheck: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SimpleProducerConsumerTest.setup: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SimpleProducerConsumerTest.stateCheck: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SimpleProducerConsumerTest.stateCheck: pulsar-broker/src/test/java/org/apache/pulsar/client/api/SimpleProducerConsumerTest.java#L84
Container startup failed for image apachepulsar/java-test-image:latest
SmokeTest.setup: tests/bc_2_0_0/src/test/java/org/apache/pulsar/tests/integration/SmokeTest.java#L50
Container startup failed for image apachepulsar/java-test-image:latest
SmokeTest.stateCheck: tests/bc_2_0_0/src/test/java/org/apache/pulsar/tests/integration/SmokeTest.java#L50
Container startup failed for image apachepulsar/java-test-image:latest
CI - Integration - Cli
The job running on runner GitHub Actions 15 has exceeded the maximum execution time of 60 minutes.
CI - Integration - Cli
The operation was canceled.
CI - Integration - LoadBalance
The job running on runner GitHub Actions 20 has exceeded the maximum execution time of 60 minutes.
CI - Integration - LoadBalance
The operation was canceled.
CI - Integration - Messaging
The job running on runner GitHub Actions 16 has exceeded the maximum execution time of 60 minutes.
CI - Integration - Messaging
The operation was canceled.
Pulsar CI checks completed
Process completed with exit code 1.
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.PulsarStandaloneTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.client.api.PatternMultiTopicsConsumerTest 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 71 new threads. There are now 89 threads in total.
CI - Unit - Brokers - Broker Group 1
Summary: Tests in class org.apache.pulsar.client.api.MultiTopicsConsumerTest created 74 new threads. There are now 83 threads in total.
CI - Unit - Other
Summary: Tests in class org.apache.bookkeeper.mledger.offload.filesystem.impl.FileSystemManagedLedgerOffloaderTest created 5 new threads. There are now 15 threads in total.
CI - Unit - Proxy
Summary: Tests in class org.apache.pulsar.proxy.server.ProxyServiceTlsStarterTest 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.AdminApiSubscriptionTest 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 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.AdminApiDelayedDeliveryTest 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.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.AdminApi2Test created 123 new threads. There are now 133 threads in total.
CI - Unit - Brokers - Broker Group 3
Summary: Tests in class org.apache.pulsar.broker.admin.v3.AdminApiTransactionTest created 77 new threads. There are now 87 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 27 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 36 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 45 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 46 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 49 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 145 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 151 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.ClientDeduplicationTest 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.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.RetryTopicTest 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.InterceptorsTest 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.SimpleProducerConsumerStatTest created 59 new threads. There are now 69 threads in total.
CI - Unit - Brokers - Client Api
Summary: Tests in class org.apache.pulsar.client.api.TlsProducerConsumerTest created 62 new threads. There are now 72 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.security.tls.ec.TlsWithECKeyStoreTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.security.tls.ec.TlsWithECCertificateFileTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.client.api.MultiRolesTokenAuthorizationProviderTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.client.api.ProducerQueueSizeTest 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.resourcegroup.ResourceGroupConfigListenerTest 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.admin.TopicsTest created 55 new threads. There are now 65 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.broker.service.persistent.ShadowTopicTest created 56 new threads. There are now 67 threads in total.
CI - Unit - Brokers - Broker Group 2
Summary: Tests in class org.apache.pulsar.broker.service.DeduplicationDisabledBrokerLevelTest created 59 new threads. There are now 69 threads in total.
CI - Unit - Pulsar Metadata
Summary: Tests in class org.apache.bookkeeper.replication.AutoRecoveryMainTest created 23 new threads. There are now 33 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 - 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.BookieAutoRecoveryTest created 15 new threads. There are now 25 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.AuditorBookieTest created 28 new threads. There are now 38 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 Impl
Summary: Tests in class org.apache.pulsar.client.impl.ConnectionPoolTest created 1 new threads. There are now 10 threads in total.
CI - Unit - Brokers - Client Impl
Summary: Tests in class org.apache.pulsar.client.processor.MessagePayloadProcessorTest 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.AutoCloseUselessClientConTXTest 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 - Client Impl
Summary: Tests in class org.apache.pulsar.client.api.DeadLetterTopicTest created 1 new threads. There are now 10 threads in total.
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 17
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
Summary: Tests in class org.apache.pulsar.io.http.HttpSinkTest created 74 new threads. There are now 83 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.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 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 - 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.text.HdfsStringSinkTests created 1 new threads. There are now 10 threads in total.
CI - Integration - Cli
No files were found with the provided path: surefire-reports. No artifacts will be uploaded.
CI - Integration - LoadBalance
No files were found with the provided path: surefire-reports. No artifacts will be uploaded.
CI - Integration - Messaging
No files were found with the provided path: surefire-reports. No artifacts will be uploaded.
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_METADATA.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". 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-BACKWARDS_COMPAT-container-logs Expired
306 KB
Integration-BACKWARDS_COMPAT-surefire-reports Expired
182 KB
Integration-CLI-container-logs Expired
130 KB
Integration-LOADBALANCE-container-logs Expired
297 KB
Integration-MESSAGING-container-logs Expired
155 KB
Integration-METRICS-container-logs Expired
28.6 KB
Integration-METRICS-surefire-reports Expired
84.6 KB
Integration-SHADE_RUN-surefire-reports Expired
144 KB
Integration-STANDALONE-container-logs Expired
66.7 KB
Integration-STANDALONE-surefire-reports Expired
133 KB
Integration-TRANSACTION-container-logs Expired
14.1 KB
Integration-TRANSACTION-surefire-reports Expired
82.4 KB
Unit-BROKER_CLIENT_API-dumps Expired
32.8 KB
Unit-BROKER_CLIENT_API-surefire-reports Expired
11.4 MB
Unit-BROKER_CLIENT_IMPL-dumps Expired
19.6 KB
Unit-BROKER_GROUP_1-dumps Expired
32.1 KB
Unit-BROKER_GROUP_1-surefire-reports Expired
9.68 MB
Unit-BROKER_GROUP_2-dumps Expired
46 KB
Unit-BROKER_GROUP_2-surefire-reports Expired
16.5 MB
Unit-BROKER_GROUP_3-dumps Expired
38.7 KB
Unit-BROKER_GROUP_3-surefire-reports Expired
10.1 MB
Unit-BROKER_GROUP_4-dumps Expired
3.83 KB
Unit-METADATA-dumps Expired
39.9 KB
Unit-OTHER-dumps Expired
4.33 KB
Unit-OTHER-surefire-reports Expired
1.62 MB
Unit-PROXY-dumps Expired
3.84 KB
Unit-PROXY-surefire-reports Expired
122 KB
Unit-PULSAR_IO-dumps Expired
74.9 KB
Unit-PULSAR_IO_ELASTIC-dumps Expired
51.1 KB
coverage_and_deps_unittest_BROKER_CLIENT_IMPL.tar.zst Expired
2.09 MB
coverage_and_deps_unittest_BROKER_GROUP_4.tar.zst Expired
1.98 MB
coverage_and_deps_unittest_CLIENT.tar.zst Expired
636 KB
coverage_and_deps_unittest_METADATA.tar.zst Expired
248 KB
coverage_and_deps_unittest_PULSAR_IO.tar.zst Expired
368 KB
coverage_and_deps_unittest_PULSAR_IO_ELASTIC.tar.zst Expired
90.6 KB
coverage_and_deps_unittest_PULSAR_IO_KAFKA_CONNECT.tar.zst Expired
170 KB
pulsar-java-test-image.zst Expired
279 MB
pulsar-maven-repository-binaries.tar.zst Expired
304 MB
pulsar-server-distribution.tar.zst Expired
215 MB