(#23594) [fix] [broker] No longer allow creating subscription that contains slash
(#24384) [fix][ml]Revert a behavior change of releasing idle offloaded ledger handle: only release idle BlobStoreBackedReadHandle
(#24397) [improve][misc] Upgrade Netty to 4.1.122.Final and tcnative to 2.0.72.Final
(#24391) [improve][broker] Add managedCursor/LedgerInfoCompressionType settings to broker.conf
(#24392) [improve][broker] Make maxBatchDeletedIndexToPersist configurable and document other related configs
(#24356) [fix][client] Fix consumer not returning encrypted messages on decryption failure with compression enabled
(#24386) [improve][broker] Added synchronized for sendMessages in Non-Persistent message dispatchers
(#24381) [improve][ml]Release idle offloaded read handle only the ref count is 0
(#24366) [fix][broker]Fix deadlock when compaction and topic deletion execute concurrently
(#19783) [improve][offloaders] Automatically evict Offloaded Ledgers from memory
(#24360) [fix][broker] expose consumer name for partitioned topic stats
(#24350) [fix][broker] Fix issue that topic policies was deleted after a sub topic deleted, even if the partitioned topic still exists
(#24354) [fix][io] Acknowledge RabbitMQ message after processing the message successfully
(#24352) [fix][broker] Ignore metadata changes when broker is not in the Started state
(#24346) [improve][broker] Enable concurrent processing of pending read Entries to avoid duplicate Reads
(#24190) [fix][broker] Resolve the issue of frequent updates in message expiration deletion rate
(#24338) [fix][ml] Fix ManagedCursorImpl.individualDeletedMessages concurrent issue
(#24331) [fix][offload] Complete the future outside of the reading loop in BlobStoreBackedReadHandleImplV2.readAsync
(#24320) [fix][cli] Fix pulsar-shell cannot produce message with quotes and space
(#24324) [fix][test] Fix flaky AutoScaledReceiverQueueSizeTest.testNegativeClientMemory
(#24316) [fix][io] Fix kinesis avro bytes handling
(#24365) [improve] Enable metrics for all broker caches
(#24359) [improve][broker]Improve the log when encountered in-flight read limitation
(#24344) [improve][ml] Offload ledgers without check ledger length
(#24286) [fix][broker]Non-global topic policies and global topic policies overwrite each other
(#24279) [fix][broker]Global topic policies do not affect after unloading topic and persistence global topic policies never affect
(#24314) [fix][test] Fix more resource leaks in tests
(#24315) [cleanup] Remove unused config autoShrinkForConsumerPendingAcksMap
(#24313) [fix][broker] Fix potential deadlock when creating partitioned topic
(#24293) [fix][broker] fix wrong method name checkTopicExists.
(#24309) [improve][cli] Make pulsar-perf termination more responsive by using Thread interrupt status
(#24307) [fix][build] Ensure that buildtools is Java 8 compatible and fix remaining compatibility issue
(#24304) [fix][test] Simplify BetweenTestClassesListenerAdapter and fix issue with BeforeTest/AfterTest annotations
(#24289) [improve][io] Add configuration parameter for disabling aggregation for Kinesis Producers
(#24302) [improve] Upgrade pulsar-client-python to 3.7.0 in Docker image
(#24299) [fix][test] Fix more Netty ByteBuf leaks in tests
(#24297) [fix][io] Fix SyntaxWarning in Pulsar Python functions
(#24282) [fix][client] Fix producer publishing getting stuck after message with incompatible schema is discarded
(#24283) [cleanup][test] Remove unused parameter from deleteNamespaceWithRetry method in MockedPulsarServiceBaseTest
(#24272) [improve][ci] Add Netty leak detection reporting to Pulsar CI
(#24277) [improve][build] Improve thread leak detector by ignoring “Attach Listener” thread
(#24263) [improve][build] Upgrade zstd version from 1.5.2-3 to 1.5.7-3
(#24281) [fix][test] Fix multiple ByteBuf leaks in tests
(#24278) [improve][build] Suppress JVM class sharing warning when running tests
(#24275) [fix][broker] Fix HashedWheelTimer leak in PulsarService by stopping it in shutdown
(#24274) [fix][misc] Fix ByteBuf leak in SchemaUtils
(#24273) [fix][misc] Fix ByteBuf leaks in tests by making ByteBufPair.coalesce release the input ByteBufPair
(#24270) [improve][build] Upgrade commons-compress version from 1.27.0 to 1.27.1
(#24268) [improve][build] Allow building and running tests on JDK 24 and upcoming JDK 25 LTS
(#24254) [fix][broker]Fix incorrect priority between topic policies and global topic policies
(#24266) [improve][ci] Disable detailed console logging for integration tests in CI
(#24241) [improve][build] Upgrade Mockito to 5.17.0 and byte-buddy to 1.15.11
(#24261) [fix][test] Fix flaky ManagedCursorTest.testLastActiveAfterResetCursor and disable failing SchemaTest
(#24244) [fix][test] Fix flaky ManagedCursorTest.testSkipEntriesWithIndividualDeletedMessages
(#24248) [improve][io][kca] support fully-qualified topic names in source records
(#24260) [improve][build] Upgrade Gradle Develocity Maven Extension dependencies
(#24258) [fix][test] Fix TestNG BetweenTestClassesListenerAdapter listener
(#24257) [fix][broker] Unregister non-static metrics collectors registered in Prometheus default registry
(#24251) [cleanup] Remove unused static fields in BrokerService
(#24252) [cleanup] remove unused config messagePublishBufferCheckIntervalInMillis
(#24249) [fix] chore: remove unused preciseTopicPublishRateLimiterEnable
(#24178) [fix][broker]fix memory leak, messages lost, incorrect replication state if using multiple schema versions(auto_produce)
(#1743) Fix listener error
(#1734) fix topic authentication issue
Change the default value of the kopAllowedNamespaces
dbe501f9e Fix the issues when releasing 4.0.4.3
eb792c253 Return empty when getting global topic policies instead of returning exception
Upgrade commons-beanutils version to fix CVE-2025-48734
Add test to verify the sts module
Fix the backup tool can not use sts to authenticate
(#1809) Use snstage org image
(#1790))) (#1793) Revert “Add release workflow
(#1790) Add release workflow
(#1784) Update to Go 1.24 to avoid CVEs
(#1778) Fix jwt cve
(#1762) Fixed version
(#1734) Fix json marshal error for Secrets when updating functions&sinks&sources
(#1758) Upgrade x/net and x/crypto
(#1750) Upgrade jwt to 4.5.1
(#1711) fix code check
(#1704) feat: Subscription get message by id json output
(#1699) Update subscription get message by id typo lederId to ledgerId
30cfe88 Fix build issue for releasing 4.0.4.3
Support invalid name
Fix resource error during update and get connectors
Fix trigger function not support partitioned input topics error
Find specified ServiceAccount using oauth2’s client role and use it when exist
validate function-mesh v0.24.1
a1840fb3 Fix the compile issue
Use RoleBinding name to save bindings in metadata
[branch-4.0] Fix license
Fix kafka permission format
Add KSN permissions
Upgrade project and sdk/java to 1.6.0
Add kafka condition
Reduce rbac filter timeout to 3 seconds by default and make it configurable
Fail back to normal config when the external config miss.
Optimize entry reader read batch
Allow to configure the http client used by Azure
Fix build script typo
Support pulsar entry write into / read from the parquet file process
[doc] WAL Cloud Storage Developer Guide
Update Metrics.md with accurate and concise descriptions