You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kafka.apache.org by kk...@apache.org on 2021/09/20 08:46:04 UTC

svn commit: r50016 - /release/kafka/3.0.0/

Author: kkarantasis
Date: Mon Sep 20 08:46:03 2021
New Revision: 50016

Log:
Release 3.0.0

Added:
    release/kafka/3.0.0/
    release/kafka/3.0.0/RELEASE_NOTES.html
    release/kafka/3.0.0/RELEASE_NOTES.html.asc
    release/kafka/3.0.0/RELEASE_NOTES.html.md5
    release/kafka/3.0.0/RELEASE_NOTES.html.sha1
    release/kafka/3.0.0/RELEASE_NOTES.html.sha512
    release/kafka/3.0.0/kafka-3.0.0-src.tgz   (with props)
    release/kafka/3.0.0/kafka-3.0.0-src.tgz.asc
    release/kafka/3.0.0/kafka-3.0.0-src.tgz.md5
    release/kafka/3.0.0/kafka-3.0.0-src.tgz.sha1
    release/kafka/3.0.0/kafka-3.0.0-src.tgz.sha512
    release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz   (with props)
    release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.asc
    release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.md5
    release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.sha1
    release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.sha512
    release/kafka/3.0.0/kafka_2.12-3.0.0.tgz   (with props)
    release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.asc
    release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.md5
    release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.sha1
    release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.sha512
    release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz   (with props)
    release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.asc
    release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.md5
    release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.sha1
    release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.sha512
    release/kafka/3.0.0/kafka_2.13-3.0.0.tgz   (with props)
    release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.asc
    release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.md5
    release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.sha1
    release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.sha512

Added: release/kafka/3.0.0/RELEASE_NOTES.html
==============================================================================
--- release/kafka/3.0.0/RELEASE_NOTES.html (added)
+++ release/kafka/3.0.0/RELEASE_NOTES.html Mon Sep 20 08:46:03 2021
@@ -0,0 +1,360 @@
+<h1>Release Notes - Kafka - Version 3.0.0</h1>
+<p>Below is a summary of the JIRA issues addressed in the 3.0.0 release of Kafka. For full documentation of the
+    release, a guide to get started, and information about the project, see the <a href="https://kafka.apache.org/">Kafka
+    project site</a>.</p>
+
+    <p><b>Note about upgrades:</b> Please carefully review the
+    <a href="https://kafka.apache.org/30/documentation.html#upgrade">upgrade documentation</a> for this release thoroughly
+    before upgrading your cluster. The upgrade notes discuss any critical information about incompatibilities and breaking
+    changes, performance changes, and any other changes that might impact your production deployment of Kafka.</p>
+
+    <p>The documentation for the most recent release can be found at
+    <a href="https://kafka.apache.org/documentation.html">https://kafka.apache.org/documentation.html</a>.</p>
+<h2>New Feature</h2>
+<ul>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8863">KAFKA-8863</a>] - Add InsertHeader and DropHeaders connect transforms KIP-145</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12471">KAFKA-12471</a>] - Implement createPartitions in KIP-500 mode</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13207">KAFKA-13207</a>] - Replica fetcher should not update partition state on diverging epoch if partition removed from fetcher</li>
+</ul>
+<h2>Improvement</h2>
+<ul>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-3745">KAFKA-3745</a>] - Consider adding join key to ValueJoiner interface</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-4793">KAFKA-4793</a>] - Kafka Connect: POST /connectors/(string: name)/restart doesn't start failed tasks</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-5235">KAFKA-5235</a>] - GetOffsetShell: support for multiple topics and consumer configuration override</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-6987">KAFKA-6987</a>] - Reimplement KafkaFuture with CompletableFuture</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-7458">KAFKA-7458</a>] - Avoid enforced processing during bootstrap phase</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8326">KAFKA-8326</a>] - Add Serde<List<Inner>> support</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8372">KAFKA-8372</a>] - Remove deprecated RocksDB#compactRange API</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8478">KAFKA-8478</a>] - Poll for more records before forced processing</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8531">KAFKA-8531</a>] - Change default replication factor config</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8613">KAFKA-8613</a>] - Make Grace Period Mandatory for Windowed Operations in Streams</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8897">KAFKA-8897</a>] - Increase Version of RocksDB</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9559">KAFKA-9559</a>] - Change the default "default serde" from ByteArraySerde to null</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9726">KAFKA-9726</a>] - IdentityReplicationPolicy for MM2 to mimic MM1</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10062">KAFKA-10062</a>] - Add a method to retrieve the current timestamp as known by the Streams app</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10201">KAFKA-10201</a>] - Update codebase to use more inclusive terms</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10449">KAFKA-10449</a>] - Connect-distributed sample configuration file does not have instructions for listeners</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10585">KAFKA-10585</a>] - Kafka Streams should clean up the state store directory from cleanup</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10619">KAFKA-10619</a>] - Producer will enable EOS by default</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10675">KAFKA-10675</a>] - Error message from ConnectSchema.validateValue() should include the name of the schema.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10697">KAFKA-10697</a>] - Remove ProduceResponse.responses</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10746">KAFKA-10746</a>] - Consumer poll timeout Expiration should be logged as WARNING not INFO. </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10767">KAFKA-10767</a>] - Add Unit Test cases for missing methods in ThreadCacheTest</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10769">KAFKA-10769</a>] - Remove JoinGroupRequest#containsValidPattern as it is duplicate to Topic#containsValidPattern</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10885">KAFKA-10885</a>] - Refactor MemoryRecordsBuilderTest/MemoryRecordsTest to avoid a lot of (unnecessary) ignored test cases</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12177">KAFKA-12177</a>] - Retention is not idempotent</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12234">KAFKA-12234</a>] - Extend OffsetFetch requests to accept multiple group ids.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12287">KAFKA-12287</a>] - Add WARN logging on consumer-groups when reset-offsets by timestamp or duration can't find an offset and defaults to latest.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12288">KAFKA-12288</a>] - Remove task-level filesystem locks</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12294">KAFKA-12294</a>] - Consider using the forwarding mechanism for metadata auto topic creation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12313">KAFKA-12313</a>] - Consider deprecating the default.windowed.serde.inner.class configs</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12329">KAFKA-12329</a>] - kafka-reassign-partitions command should give a better error message when a topic does not exist</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12335">KAFKA-12335</a>] - Upgrade junit from 5.7.0 to 5.7.1</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12344">KAFKA-12344</a>] - Support SlidingWindows in the Scala API</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12347">KAFKA-12347</a>] - Improve Kafka Streams ability to track progress</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12349">KAFKA-12349</a>] - Follow up on PartitionEpoch in KIP-500</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12362">KAFKA-12362</a>] - Determine if a Task is idling</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12379">KAFKA-12379</a>] - KIP-716: Allow configuring the location of the offsetsync topic with MirrorMaker2</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12396">KAFKA-12396</a>] - Dedicated exception for kstreams when null key received</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12398">KAFKA-12398</a>] - Fix flaky test `ConsumerBounceTest.testClose`</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12408">KAFKA-12408</a>] - Document omitted ReplicaManager metrics</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12409">KAFKA-12409</a>] - Leaking gauge in ReplicaManager</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12415">KAFKA-12415</a>] - Prepare for Gradle 7.0 and restrict transitive scope for non api dependencies</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12419">KAFKA-12419</a>] - Remove Deprecated APIs of Kafka Streams in 3.0</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12436">KAFKA-12436</a>] - deprecate MirrorMaker v1</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12439">KAFKA-12439</a>] - When in KIP-500 mode, we should be able to assign new partitions to nodes that are fenced</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12442">KAFKA-12442</a>] - Upgrade ZSTD JNI from 1.4.8-4 to 1.4.9-1</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12454">KAFKA-12454</a>] - Add ERROR logging on kafka-log-dirs when given brokerIds do not  exist in current kafka cluster</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12464">KAFKA-12464</a>] - Enhance constrained sticky Assign algorithm</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12479">KAFKA-12479</a>] - Combine partition offset requests into single request in ConsumerGroupCommand</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12483">KAFKA-12483</a>] - Enable client overrides in connector configs by default</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12484">KAFKA-12484</a>] - Enable Connect's connector log contexts by default</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12499">KAFKA-12499</a>] - Adjust transaction timeout according to commit interval on Streams EOS</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12509">KAFKA-12509</a>] - Tighten up StateDirectory thread locking</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12541">KAFKA-12541</a>] - Extend ListOffset to fetch offset with max timestamp (KIP-734)</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12573">KAFKA-12573</a>] - Removed deprecated `Metric#value`</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12574">KAFKA-12574</a>] - Deprecate eos-alpha</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12577">KAFKA-12577</a>] - Remove deprecated `ConfigEntry` constructor</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12584">KAFKA-12584</a>] - Remove deprecated `Sum` and `Total` classes</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12591">KAFKA-12591</a>] - Remove deprecated `quota.producer.default` and `quota.consumer.default` configurations</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12612">KAFKA-12612</a>] - Remove checksum from ConsumerRecord/RecordMetadata in 3.0</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12614">KAFKA-12614</a>] - Use Jenkinsfile for trunk and release branch builds</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12620">KAFKA-12620</a>] - Producer IDs generated by the controller</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12637">KAFKA-12637</a>] - Remove deprecated PartitionAssignor interface</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12662">KAFKA-12662</a>] - add unit test for ProducerPerformance</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12663">KAFKA-12663</a>] - Update FindCoordinator to resolve multiple Coordinators at a time</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12675">KAFKA-12675</a>] - Improve sticky general assignor scalability and performance</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12779">KAFKA-12779</a>] - TaskMetadata should return actual TaskId rather than plain String</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12788">KAFKA-12788</a>] - Improve KRaft replica placement</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12803">KAFKA-12803</a>] - Support reassigning partitions when in KRaft mode</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12819">KAFKA-12819</a>] - Quality of life improvements for tests</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12849">KAFKA-12849</a>] - Consider migrating TaskMetadata to interface with internal implementation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12874">KAFKA-12874</a>] - Increase default consumer session timeout to 45s (KIP-735)</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12906">KAFKA-12906</a>] - Consumer should include partition and offset number in deserialization exception</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12909">KAFKA-12909</a>] - Allow users to opt-into spurious left/outer stream-stream join improvement</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12921">KAFKA-12921</a>] - Upgrade ZSTD JNI from 1.4.9-1 to 1.5.0-1</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12922">KAFKA-12922</a>] - MirrorCheckpointTask should close topic filter</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12931">KAFKA-12931</a>] - KIP-746: Revise KRaft Metadata Records</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12934">KAFKA-12934</a>] - Move some controller classes to the metadata package</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12981">KAFKA-12981</a>] - Ensure LogSegment.maxTimestampSoFar and LogSegment.offsetOfMaxTimestampSoFar are read/updated in sync</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13000">KAFKA-13000</a>] - Improve handling of UnsupportedVersionException in MockClient</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13021">KAFKA-13021</a>] - Improve Javadocs for API Changes and address followup from KIP-633</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13026">KAFKA-13026</a>] - Idempotent producer (KAFKA-10619) follow-up testings</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13041">KAFKA-13041</a>] - Support debugging system tests with ducker-ak</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13209">KAFKA-13209</a>] - Upgrade jetty-server to fix CVE-2021-34429</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13258">KAFKA-13258</a>] - AlterClientQuotas response does not include an error when it failed</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13259">KAFKA-13259</a>] - DescribeProducers response does not include an error when it failed</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13260">KAFKA-13260</a>] - FindCoordinator errorCounts does not handle v4</li>
+</ul>
+<h2>Bug</h2>
+<ul>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-3968">KAFKA-3968</a>] - fsync() is not called on parent directory when new FileMessageSet is flushed to disk</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-5146">KAFKA-5146</a>] - Kafka Streams: remove compile dependency on connect-json</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-6435">KAFKA-6435</a>] - Application Reset Tool might delete incorrect internal topics</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-7421">KAFKA-7421</a>] - Deadlock in Kafka Connect during class loading</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8315">KAFKA-8315</a>] - Historical join issues</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8562">KAFKA-8562</a>] - SASL_SSL still performs reverse DNS lookup despite KAFKA-5051</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8784">KAFKA-8784</a>] - Remove default implementation of RocksDBConfigSetter#close</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8940">KAFKA-8940</a>] - Flaky Test SmokeTestDriverIntegrationTest.shouldWorkWithRebalance</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9186">KAFKA-9186</a>] - Kafka Connect floods logs with probably bogus error messages from DelegatingClassLoader</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9189">KAFKA-9189</a>] - Shutdown is blocked if connection to Zookeeper is lost</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9295">KAFKA-9295</a>] - KTableKTableForeignKeyInnerJoinMultiIntegrationTest#shouldInnerJoinMultiPartitionQueryable</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9527">KAFKA-9527</a>] - Application Reset Tool Returns NPE when --to-datetime or --by-duration are run on --input-topics with empty partitions </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9672">KAFKA-9672</a>] - Dead brokers in ISR cause isr-expiration to fail with exception</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9858">KAFKA-9858</a>] - CVE-2016-3189  Use-after-free vulnerability in bzip2recover in bzip2 1.0.6 allows remote attackers to cause a denial of service (crash) via a crafted bzip2 file, related to block ends set to before the start of the block.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10046">KAFKA-10046</a>] - Deprecated PartitionGrouper config is ignored</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10192">KAFKA-10192</a>] - Flaky test BlockingConnectorTest#testBlockInConnectorStop</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10340">KAFKA-10340</a>] - Source connectors should report error when trying to produce records to non-existent topics instead of hanging forever</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10614">KAFKA-10614</a>] - Group coordinator onElection/onResignation should guard against leader epoch</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12170">KAFKA-12170</a>] - Connect Cast cannot deal with fields of type "bytes" correctly</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12252">KAFKA-12252</a>] - Distributed herder tick thread loops rapidly when worker loses leadership</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12262">KAFKA-12262</a>] - New session keys are never distributed when follower with key becomes leader</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12297">KAFKA-12297</a>] - Implementation of MockProducer contradicts documentation of Callback for async send</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12303">KAFKA-12303</a>] - Flatten SMT drops some fields when null values are present</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12308">KAFKA-12308</a>] - ConfigDef.parseType deadlock</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12330">KAFKA-12330</a>] - FetchSessionCache may cause starvation for partitions when FetchResponse is full</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12336">KAFKA-12336</a>] - custom stream naming does not work while calling stream[K, V](topicPattern: Pattern) API with named Consumed parameter </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12350">KAFKA-12350</a>] - document  about refresh.topics.interval.seconds default value is not right </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12393">KAFKA-12393</a>] - Document multi-tenancy considerations</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12426">KAFKA-12426</a>] - Missing logic to create partition.metadata files in RaftReplicaManager</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12427">KAFKA-12427</a>] - Broker does not close muted idle connections with buffered data</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12474">KAFKA-12474</a>] - Worker can die if unable to write new session key</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12492">KAFKA-12492</a>] - Formatting of example RocksDBConfigSetter is messed up</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12514">KAFKA-12514</a>] - NPE in SubscriptionState</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12520">KAFKA-12520</a>] - Producer state is needlessly rebuilt on startup</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12522">KAFKA-12522</a>] - Cast SMT should allow null value records to pass through </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12548">KAFKA-12548</a>] - Invalid record error message is not getting sent to application</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12557">KAFKA-12557</a>] - org.apache.kafka.clients.admin.KafkaAdminClientTest#testClientSideTimeoutAfterFailureToReceiveResponse intermittently hangs indefinitely</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12611">KAFKA-12611</a>] - Fix using random payload in ProducerPerformance incorrectly</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12619">KAFKA-12619</a>] - Ensure LeaderChange message is committed before initializing high watermark</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12650">KAFKA-12650</a>] - NPE in InternalTopicManager#cleanUpCreatedTopics</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12655">KAFKA-12655</a>] - CVE-2021-28165 - Upgrade jetty to 9.4.39</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12660">KAFKA-12660</a>] - Do not update offset commit sensor after append failure</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12661">KAFKA-12661</a>] - ConfigEntry#equal does not compare other fields when value is NOT null </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12667">KAFKA-12667</a>] - Incorrect error log on StateDirectory close</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12672">KAFKA-12672</a>] - Running test-kraft-server-start results in error</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12677">KAFKA-12677</a>] - The raftCluster always send to the wrong active controller and never update</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12684">KAFKA-12684</a>] - The valid partition list is incorrectly replaced by the successfully elected partition list</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12686">KAFKA-12686</a>] - Race condition in AlterIsr response handling</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12691">KAFKA-12691</a>] - TaskMetadata timeSinceIdlingStarted not reporting correctly</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12700">KAFKA-12700</a>] - The admin.listeners config has wonky valid values in the docs</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12702">KAFKA-12702</a>] - Unhandled exception caught in InterBrokerSendThread</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12718">KAFKA-12718</a>] - SessionWindows are closed too early</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12730">KAFKA-12730</a>] - A single Kerberos login failure fails all future connections from Java 9 onwards</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12747">KAFKA-12747</a>] - Flaky Test RocksDBStoreTest.shouldReturnUUIDsWithStringPrefix</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12749">KAFKA-12749</a>] - Changelog topic config on suppressed KTable lost</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12752">KAFKA-12752</a>] - CVE-2021-28168 upgrade jersey to 2.34 or 3.02</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12754">KAFKA-12754</a>] - TaskMetadata endOffsets does not update when the offsets are read</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12777">KAFKA-12777</a>] - AutoTopicCreationManager does not handle response errors</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12782">KAFKA-12782</a>] - Javadocs search sends you to a non-existent URL</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12792">KAFKA-12792</a>] - Fix metrics bug and introduce TimelineInteger</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12815">KAFKA-12815</a>] - KTable.transformValue might have incorrect record metadata</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12835">KAFKA-12835</a>] - Topic IDs can mismatch on brokers (after interbroker protocol version update)</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12851">KAFKA-12851</a>] - Flaky Test RaftEventSimulationTest.canMakeProgressIfMajorityIsReachable</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12856">KAFKA-12856</a>] - Upgrade Jackson to 2.12.3</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12865">KAFKA-12865</a>] - Documentation error for Admin Client API in describe ACLs</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12866">KAFKA-12866</a>] - Kafka requires ZK root access even when using a chroot</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12867">KAFKA-12867</a>] - Trogdor ConsumeBenchWorker quits prematurely with maxMessages config</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12870">KAFKA-12870</a>] - RecordAccumulator stuck in a flushing state</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12880">KAFKA-12880</a>] - Remove deprecated Count and SampledTotal in 3.0</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12889">KAFKA-12889</a>] - log clean group consider empty log segment to avoid empty log left</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12890">KAFKA-12890</a>] - Consumer group stuck in `CompletingRebalance`</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12896">KAFKA-12896</a>] - Group rebalance loop caused by repeated group leader JoinGroups</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12897">KAFKA-12897</a>] - KRaft Controller cannot create topic with multiple partitions on a single broker cluster</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12898">KAFKA-12898</a>] - Owned partitions in the subscription must be sorted</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12904">KAFKA-12904</a>] - Connect's validate REST endpoint uses incorrect timeout</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12914">KAFKA-12914</a>] - StreamSourceNode.toString() throws with StreamsBuilder.stream(Pattern) ctor</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12925">KAFKA-12925</a>] - prefixScan missing from intermediate interfaces</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12926">KAFKA-12926</a>] - ConsumerGroupCommand's java.lang.NullPointerException at negative offsets while running kafka-consumer-groups.sh</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12945">KAFKA-12945</a>] - Remove port, host.name and related configs in 3.0</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12948">KAFKA-12948</a>] - NetworkClient.close(node) with node in connecting state makes NetworkClient unusable</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12949">KAFKA-12949</a>] - TestRaftServer's scala.MatchError: null on test-kraft-server-start.sh</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12951">KAFKA-12951</a>] - Infinite loop while restoring a GlobalKTable</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12964">KAFKA-12964</a>] - Corrupt segment recovery can delete new producer state snapshots</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12983">KAFKA-12983</a>] - onJoinPrepare is not always invoked before joining the group</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12984">KAFKA-12984</a>] - Cooperative sticky assignor can get stuck with invalid SubscriptionState input metadata</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12991">KAFKA-12991</a>] - Fix unsafe access to `AbstractCoordinator.state`</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12993">KAFKA-12993</a>] - Formatting of Streams 'Memory Management' docs is messed up </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12996">KAFKA-12996</a>] - OffsetOutOfRange not handled correctly for diverging epochs when fetch offset less than leader start offset</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13002">KAFKA-13002</a>] - listOffsets must downgrade immediately for non MAX_TIMESTAMP specs</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13003">KAFKA-13003</a>] - KafkaBroker advertises socket port instead of the configured advertised port</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13007">KAFKA-13007</a>] - KafkaAdminClient getListOffsetsCalls builds cluster snapshot for every topic partition</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13008">KAFKA-13008</a>] - Stream will stop processing data for a long time while waiting for the partition lag</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13010">KAFKA-13010</a>] - Flaky test org.apache.kafka.streams.integration.TaskMetadataIntegrationTest.shouldReportCorrectCommittedOffsetInformation()</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13029">KAFKA-13029</a>] - FindCoordinators batching can break consumers during rolling upgrade</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13033">KAFKA-13033</a>] - coordinator not available error should cause add into unmap list to do a new lookup</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13037">KAFKA-13037</a>] - "Thread state is already PENDING_SHUTDOWN" log spam</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13053">KAFKA-13053</a>] - Bump frame version for KRaft records</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13056">KAFKA-13056</a>] - Broker should not generate snapshots when controller is co-resident</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13057">KAFKA-13057</a>] - Many broker RPCs are not enable in KRaft mode</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13058">KAFKA-13058</a>] - `AlterConsumerGroupOffsetsHandler` does not handle partition errors correctly.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13073">KAFKA-13073</a>] - Simulation test fails due to inconsistency in MockLog's implementation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13078">KAFKA-13078</a>] - Closing FileRawSnapshotWriter too early</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13080">KAFKA-13080</a>] - Fetch snapshot request are not directed to kraft in controller</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13092">KAFKA-13092</a>] - Perf regression in LISR requests</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13096">KAFKA-13096</a>] - QueryableStoreProvider is not updated when threads are added/removed/replaced rendering IQ impossible</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13098">KAFKA-13098</a>] - No such file exception when recovering snapshots in metadata log dir</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13099">KAFKA-13099</a>] - Message too large error when expiring transactionalIds</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13100">KAFKA-13100</a>] - Controller cannot revert to an in-memory snapshot</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13104">KAFKA-13104</a>] - Controller should notify the RaftClient when it resigns</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13112">KAFKA-13112</a>] - Controller's committed offset get out of sync with raft client listener context</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13119">KAFKA-13119</a>] - Validate the KRaft controllerListener config on startup</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13127">KAFKA-13127</a>] - Fix stray partition lookup logic</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13129">KAFKA-13129</a>] - Fix broken system tests relate to the ConfigCommand change</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13132">KAFKA-13132</a>] - Upgrading to topic IDs in LISR requests has gaps introduced in 3.0</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13137">KAFKA-13137</a>] - KRaft Controller Metric MBean names are incorrectly quoted</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13139">KAFKA-13139</a>] - Empty response after requesting to restart a connector without the tasks results in NPE</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13141">KAFKA-13141</a>] - Leader should not update follower fetch offset if diverging epoch is present</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13143">KAFKA-13143</a>] - Disable Metadata endpoint for KRaft controller</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13160">KAFKA-13160</a>] - Fix the code that calls the broker's config handler to pass the expected default resource name when using KRaft.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13161">KAFKA-13161</a>] - Follower leader and ISR state not updated after partition change in KRaft</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13167">KAFKA-13167</a>] - KRaft broker should heartbeat immediately during controlled shutdown</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13168">KAFKA-13168</a>] - KRaft observers should not have a replica id</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13173">KAFKA-13173</a>] - KRaft controller does not handle simultaneous broker expirations correctly</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13198">KAFKA-13198</a>] - TopicsDelta doesn't update deleted topic when processing PartitionChangeRecord</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13214">KAFKA-13214</a>] - Consumer should not reset group state after disconnect</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13215">KAFKA-13215</a>] - Flaky test org.apache.kafka.streams.integration.TaskMetadataIntegrationTest.shouldReportCorrectEndOffsetInformation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13219">KAFKA-13219</a>] - BrokerState metric not working for KRaft clusters</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13262">KAFKA-13262</a>] - Mock Clients Now Have Final close() Methods</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13266">KAFKA-13266</a>] - `InitialFetchState` should be created after partition is removed from the fetchers</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13270">KAFKA-13270</a>] - Kafka may fail to connect to ZooKeeper, retry forever, and never start</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13276">KAFKA-13276</a>] - Public DescribeConsumerGroupsResult constructor refers to KafkaFutureImpl</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13277">KAFKA-13277</a>] - Serialization of long tagged string in request/response throws BufferOverflowException</li>
+</ul>
+<h2>Task</h2>
+<ul>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8405">KAFKA-8405</a>] - Remove deprecated `kafka-preferred-replica-election` command</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8734">KAFKA-8734</a>] - Remove PartitionAssignorAdapter and deprecated PartitionAssignor interface</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10070">KAFKA-10070</a>] - Parameterize Connect unit tests to remove code duplication</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10091">KAFKA-10091</a>] - Improve task idling</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12482">KAFKA-12482</a>] - Remove deprecated rest.host.name and rest.port Connect worker configs</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12519">KAFKA-12519</a>] - Consider Removing Streams Old Built-in Metrics Version </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12578">KAFKA-12578</a>] - Remove deprecated security classes/methods</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12579">KAFKA-12579</a>] - Remove various deprecated methods from clients for 3.0</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12581">KAFKA-12581</a>] - Remove deprecated Admin.electPreferredLeaders</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12588">KAFKA-12588</a>] - Remove deprecated --zookeeper in shell commands</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12590">KAFKA-12590</a>] - Remove deprecated SimpleAclAuthorizer</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12592">KAFKA-12592</a>] - Remove deprecated LogConfig.Compact</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12600">KAFKA-12600</a>] - Remove deprecated config value `default` for client config `client.dns.lookup`</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12625">KAFKA-12625</a>] - Fix the NOTICE file</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12717">KAFKA-12717</a>] - Remove internal converter config properties</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12724">KAFKA-12724</a>] - Add 2.8.0 to system tests and streams upgrade tests</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12794">KAFKA-12794</a>] - Trailing JSON tokens in DescribeProducersRequest.json can cause parse errors in some JSON parsers</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12800">KAFKA-12800</a>] - Configure jackson to to reject trailing input in the generator</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12820">KAFKA-12820</a>] - Upgrade maven-artifact dependency to resolve CVE-2021-26291</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12976">KAFKA-12976</a>] - Remove UNSUPPORTED_VERSION error from delete topics call</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12985">KAFKA-12985</a>] - CVE-2021-28169 - Upgrade jetty to 9.4.42</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13035">KAFKA-13035</a>] - Kafka Connect: Update documentation for POST /connectors/(string: name)/restart to include task Restart behavior  </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13051">KAFKA-13051</a>] - Require Principal Serde to be defined for 3.0</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13151">KAFKA-13151</a>] - Disallow policy configs in KRaft</li>
+</ul>
+<h2>Test</h2>
+<ul>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9009">KAFKA-9009</a>] - Flaky Test kafka.integration.MetricsDuringTopicCreationDeletionTest.testMetricsDuringTopicCreateDelete</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12273">KAFKA-12273</a>] - InterBrokerSendThread#pollOnce throws FatalExitError even though it is shutdown correctly</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12284">KAFKA-12284</a>] - Flaky Test MirrorConnectorsIntegrationSSLTest#testOneWayReplicationWithAutoOffsetSync</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12384">KAFKA-12384</a>] - Flaky Test ListOffsetsRequestTest.testResponseIncludesLeaderEpoch</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12561">KAFKA-12561</a>] - Fix flaky kafka.server.RaftClusterTest.testCreateClusterAndCreateListDeleteTopic()</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12629">KAFKA-12629</a>] - Failing Test: RaftClusterTest</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13045">KAFKA-13045</a>] - Add test for batched OffsetFetch requests where we have the same group in the request appear more than once</li>
+</ul>
+<h2>Sub-task</h2>
+<ul>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-7106">KAFKA-7106</a>] - Remove segment/segmentInterval from Window definition</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-7606">KAFKA-7606</a>] - Remove deprecated options from StreamsResetter</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-7785">KAFKA-7785</a>] - Remove PartitionGrouper interface and it's config and move DefaultPartitionGrouper to internal package</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9548">KAFKA-9548</a>] - SPI - RemoteStorageManager and RemoteLogMetadataManager interfaces and related classes.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10292">KAFKA-10292</a>] - fix flaky streams/streams_broker_bounce_test.py</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10434">KAFKA-10434</a>] - Remove deprecated methods on WindowStore</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10537">KAFKA-10537</a>] - Convert KStreamImpl filters to new PAPI</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10538">KAFKA-10538</a>] - Convert KStreamImpl maps to new PAPI</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10541">KAFKA-10541</a>] - Convert KTable filters to new PAPI</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10587">KAFKA-10587</a>] - Rename kafka-mirror-maker CLI command line arguments for KIP-629</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10588">KAFKA-10588</a>] - Rename kafka-console-consumer CLI command line arguments for KIP-629</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10589">KAFKA-10589</a>] - Rename kafka-replica-verification CLI command line arguments for KIP-629</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12158">KAFKA-12158</a>] - Consider better return type of RaftClient.scheduleAppend</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12173">KAFKA-12173</a>] - Migrate streams:streams-scala module to JUnit 5</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12267">KAFKA-12267</a>] - Implement DescribeTransactions API</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12368">KAFKA-12368</a>] - Inmemory implementation of RSM and RLMM. </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12369">KAFKA-12369</a>] - Implement ListTransactions API</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12429">KAFKA-12429</a>] - Serdes for all message types in internal topic which is used in default implementation for RLMM.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12434">KAFKA-12434</a>] - Admin API for DescribeProducers</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12441">KAFKA-12441</a>] - Remove deprecated methods StreamsBuilder#addGlobalStore</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12449">KAFKA-12449</a>] - Remove deprecated WindowStore#put</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12450">KAFKA-12450</a>] - Remove deprecated methods from ReadOnlyWindowStore</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12451">KAFKA-12451</a>] - Remove deprecation annotation on long-based read operations in WindowStore </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12452">KAFKA-12452</a>] - Remove deprecated overloads for ProcessorContext#forward</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12467">KAFKA-12467</a>] - Implement QuorumController metadata snapshots</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12515">KAFKA-12515</a>] - ApiVersionManager should create response based on request version</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12536">KAFKA-12536</a>] - Add Instant-based methods to ReadOnlySessionStore</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12552">KAFKA-12552</a>] - Extract segments map out of Log class into separate class</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12553">KAFKA-12553</a>] - Refactor Log layer recovery logic</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12568">KAFKA-12568</a>] - Remove deprecated "KStream#groupBy/join", "Joined#named" overloads</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12571">KAFKA-12571</a>] - Eliminate LeaderEpochFileCache constructor dependency on LogEndOffset</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12575">KAFKA-12575</a>] - Eliminate Log.isLogDirOffline boolean attribute</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12586">KAFKA-12586</a>] - Admin API for DescribeTransactions</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12596">KAFKA-12596</a>] - Remove deprecated --zookeeper in topicCommands</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12597">KAFKA-12597</a>] - Remove deprecated --zookeeper in ReassignPartitionsCommands</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12598">KAFKA-12598</a>] - Remove deprecated --zookeeper in ConfigCommand</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12630">KAFKA-12630</a>] - Remove deprecated KafkaClientSupplier#getAdminClient</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12631">KAFKA-12631</a>] - Support api to resign raft leadership</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12633">KAFKA-12633</a>] - Remove deprecated "TopologyTestDriver#pipeInput / readOutput"</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12683">KAFKA-12683</a>] - Remove deprecated "UsePreviousTimeOnInvalidTimeStamp"</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12709">KAFKA-12709</a>] - Admin API for ListTransactions</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12716">KAFKA-12716</a>] - Admin API for aborting transactions</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12758">KAFKA-12758</a>] - Create a new `server-common` module and move ApiMessageAndVersion, RecordSerde, AbstractApiMessageSerde, and BytesApiMessageSerde to that module.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12790">KAFKA-12790</a>] - Remove SslTransportLayerTest.testUnsupportedTlsVersion</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12796">KAFKA-12796</a>] - Removal of deprecated classes under `streams-scala`</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12808">KAFKA-12808</a>] - Remove Deprecated methods under StreamsMetrics</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12809">KAFKA-12809</a>] - Remove Deprecated methods under Stores</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12810">KAFKA-12810</a>] - Remove deprecated TopologyDescription.Source#topics</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12813">KAFKA-12813</a>] - Remove Deprecated schedule method in ProcessorContext</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12814">KAFKA-12814</a>] - Remove Deprecated method StreamsConfig#getConsumerConfig</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12816">KAFKA-12816</a>] - Add tier storage configs. </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12863">KAFKA-12863</a>] - Configure controller snapshot generation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12884">KAFKA-12884</a>] - Remove "--zookeeper" in system tests</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12888">KAFKA-12888</a>] - Add transaction tool</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12905">KAFKA-12905</a>] - Replace EasyMock and PowerMock with Mockito for NamedCacheMetricsTest</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12924">KAFKA-12924</a>] - Replace EasyMock and PowerMock with Mockito in streams module(metrics)</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12929">KAFKA-12929</a>] - KIP-750: Deprecate support for Java 8 in Kafka 3.0</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12930">KAFKA-12930</a>] - KIP-751: Deprecate support for Scala 2.12 in Kafka 3.0</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12940">KAFKA-12940</a>] - Enable JDK 16 builds in Jenkins</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12944">KAFKA-12944</a>] - KIP-724: Assume message format version is 3.0 when IBP is 3.0 or higher</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12952">KAFKA-12952</a>] - Metadata Snapshot File Delimiters</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12955">KAFKA-12955</a>] - Fix LogLoader to pass materialized view of segments for deletion</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12979">KAFKA-12979</a>] - Implement --find-hanging API in transaction tool</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-12992">KAFKA-12992</a>] - Make kraft configuration properties public</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13011">KAFKA-13011</a>] - Update deleteTopics Admin API</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13015">KAFKA-13015</a>] - Create System tests for Metadata Snapshots</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13023">KAFKA-13023</a>] - make "range, cooperative-sticky" as the default assignor in V3.0</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13059">KAFKA-13059</a>] - update for DeleteConsumerGroupOffsetsHandler</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13062">KAFKA-13062</a>] - refactor DeleteConsumerGroupsHandler</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13063">KAFKA-13063</a>] - refactor DescribeConsumerGroupsHandler</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13064">KAFKA-13064</a>] - refactor ListConsumerGroupOffsetsHandler</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13072">KAFKA-13072</a>] - refactor RemoveMembersFromConsumerGroupHandler</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13090">KAFKA-13090</a>] - Improve cluster snapshot integration test</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13113">KAFKA-13113</a>] - Add unregister support to the RaftClient.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13114">KAFKA-13114</a>] - Unregsiter listener during renounce when the in-memory snapshot is missing</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13116">KAFKA-13116</a>] - KIP-724: Adjust system tests due to KAFKA-12944</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-13165">KAFKA-13165</a>] - Validate node id, process role and quorum voters</li>
+</ul>

Added: release/kafka/3.0.0/RELEASE_NOTES.html.asc
==============================================================================
--- release/kafka/3.0.0/RELEASE_NOTES.html.asc (added)
+++ release/kafka/3.0.0/RELEASE_NOTES.html.asc Mon Sep 20 08:46:03 2021
@@ -0,0 +1,17 @@
+-----BEGIN PGP SIGNATURE-----
+
+iQJLBAABCAA1FiEES3BVNZOFtXEcm35jtFP0HItWruEFAmE5KqEXHGtrYXJhbnRh
+c2lzQGFwYWNoZS5vcmcACgkQtFP0HItWruHyEQ//aZyrDP0JNioghg2s5akRHAvz
+pF3TkSgImZKzDkqLmAAh44/suQy2sT3DdEy5z7vEWPduu12HVN4mD0R2jYAB9SFf
+Pvn2z0ZMDR3WCqgk2depxtmicfDQ2su/7l/OY0DI1WG2VtYDkNPZjFufdVemB/P7
+WHfXkCBcK2VXwIJpYbl7WOLRM2ClapEdZjmDLxW99Q3jdmFI+NttMDpUpdAwOfeV
+J+lZxCMc8qbd9jxFIi7oHvjyzQbifHzqsnmG7DZpu8jl8FGWAqvFprW0Vr8MQMqB
+1Qr7Hmhn615SVAjzePB/EnONlLLqxUCfnRaen+Sb844S0DFtIEFgQWWAkvphavM+
+dzL/OXsvvROyGP7ujzN5NYoX4xpGWlElA1t15p4l/3FlPe62ztXGkc//DNY283N0
+ihqGuFfw/9GKBo6t3ErMFxs2MzbfsZYeVahhA+M+QFkYznlpGcGXAHZpTDTYiFFW
+9hacxq8tKutTS5P7ZIDIR6+24BZBaLpgf6lQ+XfvvvXbY3nT+BZo7HEcudD8XNfU
+N7dAXvVKbEBINavARS+JatFCUky1WjwKsyyJCm8+LYcCAht9Vco8aunIPPDP+2Y0
+PzjlAHq6aMOkYyveU64nfcQgGZqxlkZ49n3FBJgVCOOFVYZ1UyazIll8aSZ5eawa
+sMtXmLpJaciiQiuc5TM=
+=8g/Y
+-----END PGP SIGNATURE-----

Added: release/kafka/3.0.0/RELEASE_NOTES.html.md5
==============================================================================
--- release/kafka/3.0.0/RELEASE_NOTES.html.md5 (added)
+++ release/kafka/3.0.0/RELEASE_NOTES.html.md5 Mon Sep 20 08:46:03 2021
@@ -0,0 +1 @@
+RELEASE_NOTES.html: 5C 4D C0 09 4D 18 79 E7  27 73 17 35 FF 4D 75 93

Added: release/kafka/3.0.0/RELEASE_NOTES.html.sha1
==============================================================================
--- release/kafka/3.0.0/RELEASE_NOTES.html.sha1 (added)
+++ release/kafka/3.0.0/RELEASE_NOTES.html.sha1 Mon Sep 20 08:46:03 2021
@@ -0,0 +1 @@
+RELEASE_NOTES.html: 7249 7D77 93D9 8332 369A  9EA1 05A1 10B0 BEBF 4D0A

Added: release/kafka/3.0.0/RELEASE_NOTES.html.sha512
==============================================================================
--- release/kafka/3.0.0/RELEASE_NOTES.html.sha512 (added)
+++ release/kafka/3.0.0/RELEASE_NOTES.html.sha512 Mon Sep 20 08:46:03 2021
@@ -0,0 +1,3 @@
+RELEASE_NOTES.html: 07FC2DDE 4D937166 9684D0BA 83BA369B 4317C3A6 8DE54A56
+                    220D1F1F 613A6643 050D7104 BFD4BDFA 3D78473A 656C002B
+                    C853495E E0641B1E 7B501325 D59D06D8

Added: release/kafka/3.0.0/kafka-3.0.0-src.tgz
==============================================================================
Binary file - no diff available.

Propchange: release/kafka/3.0.0/kafka-3.0.0-src.tgz
------------------------------------------------------------------------------
    svn:mime-type = application/octet-stream

Added: release/kafka/3.0.0/kafka-3.0.0-src.tgz.asc
==============================================================================
--- release/kafka/3.0.0/kafka-3.0.0-src.tgz.asc (added)
+++ release/kafka/3.0.0/kafka-3.0.0-src.tgz.asc Mon Sep 20 08:46:03 2021
@@ -0,0 +1,17 @@
+-----BEGIN PGP SIGNATURE-----
+
+iQJLBAABCAA1FiEES3BVNZOFtXEcm35jtFP0HItWruEFAmE5KqIXHGtrYXJhbnRh
+c2lzQGFwYWNoZS5vcmcACgkQtFP0HItWruHCBQ/9FyNB0snJSCM7px2Z43OkY4TG
++7gIiho36zQmOfWrR53bhQC0z1asCVP36W7vq9CZCJVL2U1YgHFYjEWJfp8u1+Xp
+h/WfcOPDAXu3F9SpkeCmcDkXw1Q75mHqPClPZJ8xXSUxjsRxQO1mLVI2C5cs48kD
+fdCwWmU6wl8qUXVkgOeX9pi+S3s1bBqFAlyIHkBc/f3Q2lQQc1twPz4dHDeQqphP
+WGl5X9ZtHaybs3OjrcobXcEBOSjcWhyyEOrMXK6+oVPn1SiLR7LVIzkGtALDcvHF
+Rng1MJ5aqd6RNBI20l647V5VMAAYwFI9waSXdUz2S8R1jlypY7NSZJ94pSpXxX7u
+HKwLrSwSKJWynZbl9twomCY2dGJ93FuRA30I/VZaYSFLqVC7OwLVr9lW/G+Uu0ms
+bN+KE99Lx/UUHnapvXqsySqUENIIxC6vB2tMM3nuLXd2C6L758AUX9DJCPQv78o3
+2V2YBns31mxvEcIfK2t7IivbmTyzwWmShVS23yxTln/AyzAGjxLVxrBBjC1HzSLa
+YoNv27g7MPToKTdxqs6BBCa1dFywCjBW5uXGL7ifXfsvPMOzzLtoVj+xM8HOtMip
+3k68hdYUQRmhxibhFJVAqM33xmKx/EPnV9tvPmpKz4MLdv7SRlEP6cdAN4gGn8Es
+Yy82TWe2JV3BJATRkzw=
+=Wsyq
+-----END PGP SIGNATURE-----

Added: release/kafka/3.0.0/kafka-3.0.0-src.tgz.md5
==============================================================================
--- release/kafka/3.0.0/kafka-3.0.0-src.tgz.md5 (added)
+++ release/kafka/3.0.0/kafka-3.0.0-src.tgz.md5 Mon Sep 20 08:46:03 2021
@@ -0,0 +1 @@
+kafka-3.0.0-src.tgz: 4B C2 19 FE 8F A1 12 EF  8E 86 F6 DC F2 E8 D6 51

Added: release/kafka/3.0.0/kafka-3.0.0-src.tgz.sha1
==============================================================================
--- release/kafka/3.0.0/kafka-3.0.0-src.tgz.sha1 (added)
+++ release/kafka/3.0.0/kafka-3.0.0-src.tgz.sha1 Mon Sep 20 08:46:03 2021
@@ -0,0 +1 @@
+kafka-3.0.0-src.tgz: 4EEE 044B BA66 F19B E20A  189B 5D2D B934 8C0C 10CC

Added: release/kafka/3.0.0/kafka-3.0.0-src.tgz.sha512
==============================================================================
--- release/kafka/3.0.0/kafka-3.0.0-src.tgz.sha512 (added)
+++ release/kafka/3.0.0/kafka-3.0.0-src.tgz.sha512 Mon Sep 20 08:46:03 2021
@@ -0,0 +1,3 @@
+kafka-3.0.0-src.tgz: AA7F7676 9579BC8C C488D1A9 B9CA5D5D E69DD172 51319AE6
+                     C4100AD3 67A7A95C D79EF6C7 00FA8EEB AD21D12C 000C9F41
+                     0CD69466 84912686 159790C7 A1FCC3A9

Added: release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz
==============================================================================
Binary file - no diff available.

Propchange: release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz
------------------------------------------------------------------------------
    svn:mime-type = application/octet-stream

Added: release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.asc
==============================================================================
--- release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.asc (added)
+++ release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.asc Mon Sep 20 08:46:03 2021
@@ -0,0 +1,17 @@
+-----BEGIN PGP SIGNATURE-----
+
+iQJLBAABCAA1FiEES3BVNZOFtXEcm35jtFP0HItWruEFAmE5KqEXHGtrYXJhbnRh
+c2lzQGFwYWNoZS5vcmcACgkQtFP0HItWruFKkA/+MM5oNK5nZa2o3vJCb2grbzEP
+shStWi4XhmfwdLcbwd++1vDUeMmoBBhFG7oOQBJN1Op8CHZzCDjRkEMyF/HDd/R1
+6GqMGmi5J2/OztruFdGAht/P0JFZmA6bESgF8KS0wSXyyZVXI5T/T9iCArtdij40
+gETKhogKv60lo9fg/GOOIHix/+I8nlecRVQdmyh8xZLmE+rncSDKB6XqIIqSk5lL
+AY9QatqnUi1mRpc1BwHWGFG0+J63WAXmdOIhCLMF95WAwwrevxjnoWXnw3eVH+Sm
+wSV5s4Vxr0f51Zt2Yjc/OkbkU9pY4ZSC3WW5S0ZFp8VAM8h2+N2PioP5RmzhQ0st
+izqDibAuWDhK8E2CrGGM2hLpPPSGlKu/afqadwnSyrJDCzxZwhSgcp+JjPRauQw5
+MtB1ut67vlAPHkuYd6C7CuWLnOb05tLOIbEqHIn/pjnu46yomdQEXwux7AsWn4mq
+9OFHoT1zmIWHl8a4goBjQnRVhE7CMmPx7TZWIg8gba0cMOdpoQudBXSdK/Y7zMhH
+1Ubf/nIPOPgav61K+9IYNdGo5+cqahmNerdvNVfP6p7JntZs3Dq9++LP412zXkI1
+SrcoHJO7Wg6p8nkjgfYV9ihV8DVJsDRBWwJeT2nFquOHSUQXHGh4N//pDtfWZpd6
+dvbaVFzMjrw8B2k0nfA=
+=vmzP
+-----END PGP SIGNATURE-----

Added: release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.md5
==============================================================================
--- release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.md5 (added)
+++ release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.md5 Mon Sep 20 08:46:03 2021
@@ -0,0 +1 @@
+kafka_2.12-3.0.0-site-docs.tgz: E5 36 E5 17 14 A3 F3 E5  85 A7 B0 97 B8 7C CC 54

Added: release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.sha1
==============================================================================
--- release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.sha1 (added)
+++ release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.sha1 Mon Sep 20 08:46:03 2021
@@ -0,0 +1,2 @@
+kafka_2.12-3.0.0-site-docs.tgz: 5A12 9E53 F1B3 33C2 402A  54F2 7A47 8F44 20B4
+                                A202

Added: release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.sha512
==============================================================================
--- release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.sha512 (added)
+++ release/kafka/3.0.0/kafka_2.12-3.0.0-site-docs.tgz.sha512 Mon Sep 20 08:46:03 2021
@@ -0,0 +1,4 @@
+kafka_2.12-3.0.0-site-docs.tgz: 84833B4B D885FF3A 506372D8 78D77823 BFE84741
+                                62D529AB 9BDE8D77 8C6D834E 13CF0CCC 7156819A
+                                29F55415 55976C9E 4DFD47B6 9B222F60 96F044E5
+                                7D1584C8

Added: release/kafka/3.0.0/kafka_2.12-3.0.0.tgz
==============================================================================
Binary file - no diff available.

Propchange: release/kafka/3.0.0/kafka_2.12-3.0.0.tgz
------------------------------------------------------------------------------
    svn:mime-type = application/octet-stream

Added: release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.asc
==============================================================================
--- release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.asc (added)
+++ release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.asc Mon Sep 20 08:46:03 2021
@@ -0,0 +1,17 @@
+-----BEGIN PGP SIGNATURE-----
+
+iQJLBAABCAA1FiEES3BVNZOFtXEcm35jtFP0HItWruEFAmE5KqMXHGtrYXJhbnRh
+c2lzQGFwYWNoZS5vcmcACgkQtFP0HItWruHkehAAh+4aoKpgas7NGN6gQkiGbsYa
+noR/rbwbGbLN1fIfPbfrv2iddlKuofVmgRpq+oBWBSklNDF3DSLqB+BKRBsvnzQi
+Ty5qGmouBEGuhWk8xIQLX7UUNqeEDekWRabMUuKSSR74KrDIEXZqC0S57godl0zH
+oVYnL3dqgfTrA6Ks/v21iIBUpuM5+JCCZrdwxq/TzUKmLN+Auz2Z8XE1gibfDDhN
+oI1r5/nE6WrOQdgDxRDJD2rCeLtjdl5fFah9bZFFP81jTYdenIpTL3lLfZUK9D90
+r7jcy+5BoujGHPa4+h4vMpb0TZoJkSRKycQOilsbK8zMnQoEj/DhFmBXyxKI5hwM
+iSULIar6KhgN61fGHgdx+Ks35N0PCVxeEXoOXzAUaiczQrkhCa5mHIcEX0Lo1L+7
+ymnWQFF2/+m5eUb6tQAhlQFoROpV/noTlZwyw0LUdqNtKjP+Wk5MN5pEpe5B1lFk
+jE3SN1a7/VBJKX+HfLIQ4Z/y3VRTI4smIEp+TO9JgOZAtN5rmifgjpy4Gr8D7cJM
+8XZ5ON1bYMpyLntAZkUqo57mTx2RL1lWs8QlHNbmduHuAmrASFMqNQCROq9Iq7mS
+XhhTWEN9Uj5H8+uF6yrk36XsJn/9y0C6ptBbuGGSD54s90nvRwjx4sxDZ6kZX/rU
+4yR1RB2HBRDBt+pleqE=
+=QAdg
+-----END PGP SIGNATURE-----

Added: release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.md5
==============================================================================
--- release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.md5 (added)
+++ release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.md5 Mon Sep 20 08:46:03 2021
@@ -0,0 +1 @@
+kafka_2.12-3.0.0.tgz: B3 E6 ED 94 8F 4C 14 81  7D 1A 34 06 F4 06 6C 29

Added: release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.sha1
==============================================================================
--- release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.sha1 (added)
+++ release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.sha1 Mon Sep 20 08:46:03 2021
@@ -0,0 +1 @@
+kafka_2.12-3.0.0.tgz: F74F 1A6E EB15 7B65 FBE9  CFF4 1288 02B5 B959 5FCC

Added: release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.sha512
==============================================================================
--- release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.sha512 (added)
+++ release/kafka/3.0.0/kafka_2.12-3.0.0.tgz.sha512 Mon Sep 20 08:46:03 2021
@@ -0,0 +1,3 @@
+kafka_2.12-3.0.0.tgz: CB82E685 A76FA604 1DCB39A8 519B4F3C 1A16066E 9D5D8EAB
+                      11A825B5 17D91F69 0ED9AF40 492A1147 1265AE9C 486017FD
+                      128492F8 67E3BE63 EC7770D4 4F7E54D2

Added: release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz
==============================================================================
Binary file - no diff available.

Propchange: release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz
------------------------------------------------------------------------------
    svn:mime-type = application/octet-stream

Added: release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.asc
==============================================================================
--- release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.asc (added)
+++ release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.asc Mon Sep 20 08:46:03 2021
@@ -0,0 +1,17 @@
+-----BEGIN PGP SIGNATURE-----
+
+iQJLBAABCAA1FiEES3BVNZOFtXEcm35jtFP0HItWruEFAmE5KqIXHGtrYXJhbnRh
+c2lzQGFwYWNoZS5vcmcACgkQtFP0HItWruGWORAAi63nz0pkBlPDauFGeYDSJGiN
+3vu00/6B5EisugnsACyIbgAL+KYKEWbc0c30MqgwHgUOz3gcHcSKyhoF7zwzlDnk
+nK/5Y/XiGOhc89ZohXRj/c8EzppZloUcpM+Efdd5u1raKu5BLsQPO4U8VSj7mBVY
+sWRiVsvPKG9QVG5IxmgSTegcndzWKLV6D5XqwcsIiCIQ4UKfbMqGadTpuduE2Ft9
+Aj4ESH4x/zgV4p95iCTEggBecqjonZmyopPJ/JooC2sMO03CQGo+na2S6ZZqq1c/
+hUslyNdWHyodB47xDYRgTOeSD/L55P5V3Lvr8L1J7+r4VjlljHFC6H6zW+3j1m3b
+NvMUpslbFyp6A5q3s3gFMCIQ9VwBe2Dna/Am6dbXErQyXO8YC32FHk5O7rcQNDO6
+6NMEUZHc1/WxkkkC9ZK6Mmx4NamcV+gmTU4Z5jrR9Q4SSRSb3AkfUidDYBHOqK9Q
+3YATgs5T2UX7MhBMo6t7nV1+tRTG2GypVJXTpzyHLTDy38xyN75vNQmG2qPD4kSx
+tt0Kt+T041Ys7qm5zaVMowWhj8UQT3qZ2TUFrBbNicm3GmCzd9DVwNBVSJ8lmVbl
+bwebZsbzmORdKe9s0j4EdAZBi22SBs0e5oGc9mNAinMnSeNwsMLq2lAfxEzZFTKR
+/4xx8I8+RD+LpAKI3Gg=
+=nqAP
+-----END PGP SIGNATURE-----

Added: release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.md5
==============================================================================
--- release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.md5 (added)
+++ release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.md5 Mon Sep 20 08:46:03 2021
@@ -0,0 +1 @@
+kafka_2.13-3.0.0-site-docs.tgz: 99 97 10 27 50 0F A3 3D  37 6D 02 53 34 72 A4 B6

Added: release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.sha1
==============================================================================
--- release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.sha1 (added)
+++ release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.sha1 Mon Sep 20 08:46:03 2021
@@ -0,0 +1,2 @@
+kafka_2.13-3.0.0-site-docs.tgz: 87A9 E517 61A4 CFD4 C6EF  42BE AA29 B384 7E90
+                                C920

Added: release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.sha512
==============================================================================
--- release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.sha512 (added)
+++ release/kafka/3.0.0/kafka_2.13-3.0.0-site-docs.tgz.sha512 Mon Sep 20 08:46:03 2021
@@ -0,0 +1,4 @@
+kafka_2.13-3.0.0-site-docs.tgz: 5EE91904 448DAA8C C806E87F 258F2AC1 F5D7BD05
+                                C43FC795 A9B4148E C334E0F1 F8F5A5B6 FA7B0573
+                                B556DC41 C2321DF9 28CC93AE D98F6298 2A73095D
+                                F70F2003

Added: release/kafka/3.0.0/kafka_2.13-3.0.0.tgz
==============================================================================
Binary file - no diff available.

Propchange: release/kafka/3.0.0/kafka_2.13-3.0.0.tgz
------------------------------------------------------------------------------
    svn:mime-type = application/octet-stream

Added: release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.asc
==============================================================================
--- release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.asc (added)
+++ release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.asc Mon Sep 20 08:46:03 2021
@@ -0,0 +1,17 @@
+-----BEGIN PGP SIGNATURE-----
+
+iQJLBAABCAA1FiEES3BVNZOFtXEcm35jtFP0HItWruEFAmE5KqUXHGtrYXJhbnRh
+c2lzQGFwYWNoZS5vcmcACgkQtFP0HItWruFJ3w//bWjHPkKYN9px2WTSusIZSb3H
+RT0Jr0gIaa4iXsUjX1ZlGtNkqbxXuGlueJ3xnh1TgT8HYy5CEVYQ2DUCwyrw3Gr/
+B1SROeGCmEFhvENncmce26UtyIAAdHQ2XyaBsqpWurXM+hReNK0stMBcX3XNlXjo
++Y3Mtj3ZXCy2PH6nrqhapEdN+BJKHRgapLYZwe6Qhid1gwrYrN71taT9jNMqfvAp
+Sj1q8pE4/QVAnQfLBvit5Dwn4LocH20IaMwkLRI6wwQ6g6SEsTCpP4318f6jPyg5
+VhziCeEKICvMTKMNIl9ZDMY6PDpKpIO+Qo1Eyu1QL/5MoVH2+tAdai0f6uUcgeTX
+EowM5Qy5WLQyVAaluWpw/t9+HK3tZ/a1+YzQFV4n2Pk7n+oTzLycuWBe2rz/+md0
+NQcTMY8pSgyMKqaSODALvInjMF46gKAputOsqhDyYOOtvu0nvFjwRLI4/6wWPrHb
+I3s6aW4aa3hL4Fc9HvkcUbNdG2+bSh8BE1jkti2oYJTykYIS+thTCQrY9ZyWYu5B
+MqRAXm6N3mq5xd351kNLOtMdeesUGEr8LExrNoot+LCg/MajOKPDndEKMwoo9the
+acrbCzkAUjhjAHiQxfrOIGGJwLifDrMpLd7wVunbX6DFJsA/WPw67jv19q3eotXv
+crc2pda/lPigOqszFIk=
+=SX9H
+-----END PGP SIGNATURE-----

Added: release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.md5
==============================================================================
--- release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.md5 (added)
+++ release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.md5 Mon Sep 20 08:46:03 2021
@@ -0,0 +1 @@
+kafka_2.13-3.0.0.tgz: 53 EB D9 88 E5 A6 EA B1  CB FB B2 02 FC EA B3 FA

Added: release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.sha1
==============================================================================
--- release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.sha1 (added)
+++ release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.sha1 Mon Sep 20 08:46:03 2021
@@ -0,0 +1 @@
+kafka_2.13-3.0.0.tgz: 3E5B A4D9 EDF8 5E5E 5D04  46B8 36E6 52A5 8051 30A0

Added: release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.sha512
==============================================================================
--- release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.sha512 (added)
+++ release/kafka/3.0.0/kafka_2.13-3.0.0.tgz.sha512 Mon Sep 20 08:46:03 2021
@@ -0,0 +1,3 @@
+kafka_2.13-3.0.0.tgz: 86CDEB04 AF123399 858D0343 1E977794 8C1C40EC 0D843966
+                      CF9BD90B 8235B47E BBB5CB96 D1F06607 10B9286D A86BBB5E
+                      E65E21E7 57606F5A 1E67F970 AE5CF57C