Versions Compared

Key

  • This line was added.
  • This line was removed.
  • Formatting was changed.

...

Please insert new rows in sorted order (by KIP number).


KIP

Release

1KIP-436: Add a metric indicating start time2.3.0 (WIP)
2KIP-415: Incremental Cooperative Rebalancing in Kafka Connect2.3.0 (WIP)
23KIP-427: Add AtMinIsr topic partition category (new metric & TopicCommand option)2.3.0 (WIP)
34KIP-430 - Return Authorized Operations in Describe Responses2.3.0 (WIP)
45KIP-428: Add in-memory window store2.3.0
56KIP-425: Add some Log4J Kafka Appender Properties for Producing to Secured Brokers2.3.0
67KIP-420: Add Single Value Fetch in Session Stores2.2.0
78KIP-412: Extend Admin API to support dynamic application log levels2.3.0 (WIP)
89KIP-414: Expose Embedded ClientIds in Kafka Streams2.2.0
910KIP-402: Improve fairness in SocketServer processors2.2.0 (WIP)
1011KIP-394: Require member.id for initial join group request2.2.0
1112KIP-393: Time windowed serde to properly deserialize changelog input topic2.2.0
1213KIP-386: Standardize on Min/Avg/Max metrics' default value2.2.0
1314KIP-382: MirrorMaker 2.02.3.0 (WIP)
1415KIP-380: Detect outdated control requests and bounced brokers using broker generation2.2.0
1516KIP-377: TopicCommand to use AdminClient2.2.0
1617KIP-376: Implement AutoClosable on appropriate classes that want to be used in a try-with-resource statement2.2.0
1718KIP-374: Add '--help' option to all available Kafka CLI commands2.2.0
1819KIP-372: Naming Repartition Topics for Joins and Grouping2.1.0
1920KIP-371: Add a configuration to build custom SSL principal name2.2.0
2021KIP 368: Allow SASL Connections to Periodically Re-Authenticate2.2.0
2122KIP-367 Introduce close(Duration) to Producer and AdminClient instead of close(long, TimeUnit)2.2.0
2223KIP-366: Make FunctionConversions deprecated2.1.0
2324KIP-365: Materialized, Serialized, Joined, Consumed and Produced with implicit Serde2.1.0
2425KIP-361: Add Consumer Configuration to Disable Auto Topic Creation2.3.0 (WIP)
2526KIP-359: Verify leader epoch in produce requests2.3.0 (WIP)
2627KIP-358: Migrate Streams API to Duration instead of long ms times2.1.0
2728KIP-357: Add support to list ACLs per principal2.1.0
2829KIP-356: Add withCachingDisabled() to StoreBuilder2.1.0
2930KIP-353: Improve Kafka Streams Timestamp Synchronization2.1.0
3031KIP-351: Add --under-min-isr option to describe topics command2.3.0
3132KIP-346: Improve LogCleaner behavior on error2.1
3233KIP-342 Add support for custom SASL extensions in OAuthBearer authentication2.1.0
3334KIP-341: Update Sticky Assignor's User Data Protocol2.3.0 (WIP)
3435KIP-340: Allow kafka-reassign-partitions.sh and kafka-log-dirs.sh to take admin client property file2.1.0
3536KIP-339: Create a new IncrementalAlterConfigs API2.3.0 (WIP)
3637KIP-338 Support to exclude the internal topics in kafka-topics.sh command2.1.0
3738KIP-336: Consolidate ExtendedSerializer/Serializer and ExtendedDeserializer/Deserializer2.1.0
3839KIP-332: Update AclCommand to use AdminClient API2.1.0
3940KIP-331 Add default implementation to close() and configure() for Serializer, Deserializer and Serde2.3.0 (WIP)
4041KIP-330: Add retentionPeriod in SessionBytesStoreSupplier2.1.0
4142KIP-328: Ability to suppress updates for KTables2.1.0 (partially implemented) / 2.3.0 (WIP)
4243KIP-324: Add method to get metrics() in AdminClient2.1.0
4344KIP-322: Return new error code for DeleteTopics API when topic deletion disabled.2.1.0
4445KIP-321: Update TopologyDescription to better represent Source and Sink Nodes2.1.0
4546KIP-320: Allow fetchers to detect and handle log truncation2.1.0 (partially implemented) / 2.2.0
4647KIP-319: Replace segments with segmentInterval in WindowBytesStoreSupplier2.1.0
4748KIP-313: Add KStream.flatTransform and KStream.flatTransformValues 

2.2.0 (partially implemented)

/ 2.3.0 (WIP)

4849KIP-312 Add Overloaded StreamsBuilder Build Method to Accept java.util.Properties2.1.0
4950KIP-308: Support dynamic update of max.connections.per.ip/max.connections.per.ip.overrides2.1.0
5051KIP-306: Configuration for Delaying Response to Failed Authentication2.1.0
5152KIP-305: Add Connect primitive number converters2.0.0
5253KIP-303: Add Dynamic Routing in Streams Sink2.0.0
5354KIP-302 - Enable Kafka clients to use all DNS resolved IP addresses2.1.0
5455KIP-298: Error Handling in Connect2.0.0
5556KIP-297: Externalizing Secrets for Connect Configurations2.0.0
5657KIP-295 Add Streams Configuration Allowing for Optional Topology Optimization2.0.0
5758KIP-294 - Enable TLS hostname verification by default2.0.0
5859KIP-292: Add transformValues() method to KTable2.0.0
5960KIP-290: Support for Prefixed ACLs2.0.0
6061KIP-289: Improve the default group id behavior in KafkaConsumer2.2.0
6162KIP-285: Connect Rest Extension Plugin2.0.0
6263KIP-284: Set default retention ms for Streams repartition topics to Long.MAX_VALUE2.0.0
6364KIP-283: Efficient Memory Usage for Down-Conversion2.0.0
6465KIP-282: Add the listener name to the authentication context2.0.0
6566KIP-281: ConsumerPerformance: Increase Polling Loop Timeout and Make It Reachable by the End User2.0.0
6667KIP-279: Fix log divergence between leader and follower after fast leader fail over2.0.0
6768KIP-278 - Add version option to Kafka's commands2.0.0
6869KIP-277 - Fine Grained ACL for CreateTopics API2.0.0
6970KIP-276 - Add StreamsConfig prefix for different consumers2.0.0
7071KIP-274: Kafka Streams Skipped Records Metrics2.0.0
7172KIP-272: Add API version tag to broker's RequestsPerSec metric2.0.0
7273KIP-270 - A Scala Wrapper Library for Kafka Streams2.0.0
7374KIP-268: Simplify Kafka Streams Rebalance Metadata Upgrade2.0.0
7475KIP-267: Add Processor Unit Test Support to Kafka Streams Test Utils2.0.0
7576KIP-266: Fix consumer indefinite blocking behavior2.0.0
7677KIP-265: Make Windowed Serde to public APIs2.0.0
7778KIP-261: Add Single Value Fetch in Window Stores2.0.0
7879KIP-258: Allow to Store Record Timestamps in RocksDB2.3.0
7980KIP-257 - Configurable Quota Management2.0.0
8081KIP-255: OAuth Authentication via SASL/OAUTHBEARER2.0.0
8182KIP-251: Allow timestamp manipulation in Processor API2.0.0
8283KIP-249: Add Delegation Token Operations to KafkaAdminClient2.0.0
8384KIP-247: Add public test utils for Kafka Streams1.1.0
8485KIP-245: Use Properties instead of StreamsConfig in KafkaStreams constructor2.0.0
8586KIP-244: Add Record Header support to Kafka Streams Processor API2.0.0
8687KIP-243: Make ProducerConfig and ConsumerConfig constructors public1.1.0
8788KIP-239 Add queryableStoreName() to GlobalKTable1.1.0
8889KIP-238: Expose Kafka cluster ID in Connect REST API1.1.0
8990KIP-237: More Controller Health Metrics2.0.0
9091KIP-235: Add DNS alias support for secured connection2.1.0
9192KIP-233: Simplify StreamsBuilder#addGlobalStore1.1.0
9293KIP-231: Improve the Required ACL of ListGroups API2.1.0
9394KIP-229: DeleteGroups API1.1.0
9495KIP-227 - Introduce Incremental FetchRequests to Increase Partition Scalability1.1.0
9596KIP-226 - Dynamic Broker Configuration1.1.0
9697KIP-225 - Use tags for consumer “records.lag” metrics1.1.0
9798KIP-224: Add configuration parameter `retries` to Streams API1.1.0
9899KIP-223 - Add per-topic min lead and per-partition lead metrics to KafkaConsumer2.0.0
99100KIP-222 - Add Consumer Group operations to Admin API2.0.0
100101KIP-220: Add AdminClient into Kafka Streams' ClientSupplier1.1.0
101102KIP-219 - Improve quota communication2.0.0
102103KIP-218: Make KafkaFuture.Function java 8 lambda compatible1.1.0
103104KIP-215: Add topic regex support for Connect sinks1.1.0
104105KIP-214: Add zookeeper.max.in.flight.requests config to the broker1.1.0
105106KIP-213 Support non-key joining in KTable2.3.0 (WIP)
106107KIP-212: Enforce set of legal characters for connector names1.1.0
107108KIP-211: Revise Expiration Semantics of Consumer Group Offsets2.1.0
108109KIP-210 - Provide for custom error handling when Kafka Streams fails to produce1.1.0
109110KIP-208: Add SSL support to Kafka Connect REST interface1.1.0
110111KIP-207: Offsets returned by ListOffsetsResponse should be monotonically increasing even during a partition leader change2.2.0
111112KIP-206: Add support for UUID serialization and deserialization2.1.0
112113KIP-205: Add all() and range() API to ReadOnlyWindowStore1.1.0
113114KIP-204 : Adding records deletion operation to the new Admin Client API1.1.0
114115KIP-203: Add toLowerCase support to sasl.kerberos.principal.to.local rule 1.1.0
115116KIP-202: Move merge() from StreamsBuilder to KStream1.0.0
116117KIP-198: Remove ZK dependency from Streams Reset Tool1.0.0
117118KIP-197 Connect REST API should include the connector type when describing a connector1.0.0
118119KIP-196: Add metrics to Kafka Connect framework1.0.0
119120KIP-195: AdminClient.createPartitions1.0.0
120121KIP-192 : Provide cleaner semantics when idempotence is enabled1.0.0
121122KIP-191: KafkaConsumer.subscribe() overload that takes just Pattern1.0.0
122123KIP-190: Handle client-ids consistently between clients and brokers1.0.0
123124KIP-189: Improve principal builder interface and add support for SASL1.0.0
124125KIP-188 - Add new metrics to support health checks1.0.0
125126KIP-187 - Add cumulative count metric for all Kafka rate metrics1.0.0
126127KIP-186: Increase offsets retention default to 7 days2.0.0
127128KIP-183 - Change PreferredReplicaLeaderElectionCommand to use AdminClient2.2.0
128129KIP-182: Reduce Streams DSL overloads and allow easier use of custom storage engines1.0.0
129130KIP-180: Add a broker metric specifying the number of consumer group rebalances in progress1.1.0
130131KIP-177: Consumer perf tool should count rebalance time1.0.0
131132KIP-176: Remove deprecated new-consumer option for tools2.0.0
132133KIP-175: Additional '--describe' views for ConsumerGroupCommand1.1.0
133134KIP-174 - Deprecate and remove internal converter configs in WorkerConfig2.0.0
134135KIP-173: Add prefix to StreamsConfig to enable setting default internal topic configs1.0.0
135136KIP-171 - Extend Consumer Group Reset Offset for Stream Application1.1.0
136137KIP-168: Add GlobalTopicCount and GlobalPartitionCount metric per cluster1.0.0
137138KIP-167: Add interface for the state store restoration process1.0.0
138139

KIP-164 - Add UnderMinIsrPartitionCount and per-partition UnderMinIsr metrics

1.0.0
139140

KIP-163: Lower the Minimum Required ACL Permission of OffsetFetch

1.0.0
140141KIP-162: Enable topic deletion by default1.0.0
141142KIP-161: streams deserialization exception handlers1.0.0
142143KIP-160: Augment KStream.print(), KStream.writeAsText() to allow users pass in extra parameters in the printed string1.0.0
143144KIP-157 - Add consumer config options to streams reset tool1.0.0
144145KIP-156 Add option "dry run" to Streams application reset tool0.11.0.0
145146KIP-155 - Add range scan for windowed state stores0.11.0.0
146147KIP-154 Add Kafka Connect configuration properties for creating internal topics0.11.0.0
147148KIP-153: Include only client traffic in BytesOutPerSec metric0.11.0.0
148149KIP-152 - Improve diagnostics for SASL authentication failures1.0.0
149150KIP-151 Expose Connector type in REST API0.11.0.0
150151KIP-150 - Kafka-Streams Cogroup2.3.0 (WIP)
151152KIP-149: Enabling key access in ValueTransformer, ValueMapper, and ValueJoiner1.1.0 (partially implemented)
(WIP for 2.3.0)
152153KIP-146 - Classloading Isolation in Connect

0.11.0.0

153154KIP-145 - Expose Record Headers in Kafka Connect1.1.0
154155KIP-144: Exponential backoff for broker reconnect attempts0.11.0.0
155156KIP-143: Controller Health Metrics0.11.0.0
156157KIP-140: Add administrative RPCs for adding, deleting, and listing ACLs0.11.0.0
157158KIP-138: Change punctuate semantics1.0.0
158159KIP-137: Enhance TopicCommand --describe to show topics marked for deletion0.11.0.0
159160KIP-136: Add Listener name to SelectorMetrics tags0.11.0.0
160161KIP-134: Delay initial consumer group rebalance0.11.0.0
161162KIP-133: Describe and Alter Configs Admin APIs0.11.0.0
162163KIP-130: Expose states of active tasks to KafkaStreams public API1.0.0
163164KIP-129: Streams Exactly-Once Semantics0.11.0.0
164165KIP-128: Add ByteArrayConverter for Kafka Connect0.11.0.0
165166KIP-126 - Allow KafkaProducer to split and resend oversized batches.0.11.0.0
166167KIP-124 - Request rate quotas0.11.0.0
167168KIP-123: Allow per stream/table timestamp extractor0.11.0.0
168169KIP-122: Add Reset Consumer Group Offsets tooling0.11.0.0
169170KIP-121: Add KStream peek method

0.11.0.0

170171KIP-120: Cleanup Kafka Streams builder API1.0.0
171172KIP-119: Drop Support for Scala 2.10 in Kafka 0.110.11.0.0
172173KIP-118: Drop Support for Java 72.0.0
173174KIP-117: Add a public AdminClient API for Kafka admin operations0.11.0.0
174175KIP-115: Enforce offsets.topic.replication.factor upon __consumer_offsets auto topic creation0.11.0.0
175176KIP-114: KTable state stores and improved semantics0.11.0.0
176177KIP-113: Support replicas movement between log directories1.1.0
177178KIP-112: Handle disk failure for JBOD1.0.0
178179KIP-110: Add Codec for ZStandard Compression2.1.0
179180KIP-109: Old Consumer Deprecation0.11.0.0
180181KIP-108: Create Topic Policy0.10.2.0
181182KIP-107: Add deleteRecordsBefore() API in AdminClient0.11.0.0
182183

KIP-106 - Change Default unclean.leader.election.enabled from True to False

0.11.0.0
183184KIP-105: Addition of Record Level for Sensors0.10.2.0
184185KIP-104: Granular Sensors for Streams 0.10.2.0
185186KIP-103: Separation of Internal and External traffic0.10.2.0
186187KIP-102 - Add close with timeout for consumers0.10.2.0
187188KIP-101 - Alter Replication Protocol to use Leader Epoch rather than High Watermark for Truncation0.11.0.0
188189KIP-100 - Relax Type constraints in Kafka Streams API0.10.2.0
189190KIP-99: Add Global Tables to Kafka Streams0.10.2.0
190191KIP-98 - Exactly Once Delivery and Transactional Messaging0.11.0.0
191192KIP-97: Improved Kafka Client RPC Compatibility Policy0.10.2.0
192193KIP-96 - Add per partition metrics for in-sync and assigned replica count0.10.2.0
193194KIP-94 Session Windows0.10.2.0
194195KIP-93: Improve invalid timestamp handling in Kafka Streams0.10.2.0
195196KIP-92 - Add per partition lag metrics to KafkaConsumer0.10.2.0
196197KIP-91 Provide Intuitive User Timeouts in The Producer2.1.0
197198KIP-90 - Remove zkClient dependency from Streams0.10.2.0
198199KIP-89: Allow sink connectors to decouple flush and offset commit0.10.2.0
199200KIP-88: OffsetFetch Protocol Update0.10.2.0
200201KIP-86: Configurable SASL callback handlers2.0.0
201202KIP-85: Dynamic JAAS configuration for Kafka clients0.10.2.0
202203KIP-84: Support SASL SCRAM mechanisms0.10.2.0
203204KIP-82 - Add Record Headers0.11.0.0
204205KIP-81: Bound Fetch memory usage in the consumer2.2.0 (WIP)
205206KIP-79 - ListOffsetRequest/ListOffsetResponse v1 and add timestamp search methods to the new consumer0.10.1.0
206207KIP-78: Cluster Id0.10.1.0
207208KIP-77: Improve Kafka Streams Join Semantics0.10.2.0
208209KIP-75 - Add per-connector Converters0.10.1.0
209210KIP-74: Add Fetch Response Size Limit in Bytes0.10.1.0
210211KIP-73: Replication Quotas0.10.1.0
211212KIP-72: Allow putting a bound on memory consumed by Incoming request 1.0.0
212213KIP-71: Enable log compaction and deletion to co-exist0.10.1.0
213214KIP-70: Revise Partition Assignment Semantics on New Consumer's Subscription Change0.10.1.0
214215KIP-67: Queryable state for Kafka Streams0.10.1.0
215216KIP-66: Single Message Transforms for Kafka Connect0.10.2.0 / 0.11.0.0
216217KIP-65: Expose timestamps to Connect0.10.1.0
217218KIP-63: Unify store and downstream caching in streams0.10.1.0
218219KIP-62: Allow consumer to send heartbeats from a background thread0.10.1.0
219220KIP-60 - Make Java client classloading more flexible0.10.1.0
220221KIP-58 - Make Log Compaction Point Configurable0.10.1.0
221222KIP-57 - Interoperable LZ4 Framing0.10.0.0
222223KIP-56: Allow cross origin HTTP requests on all HTTP methods0.10.0.0
223224KIP-55: Secure Quotas for Authenticated Users0.10.1.0
224225KIP-54: Sticky Partition Assignment Strategy0.11.0.0
225226KIP-52: Connector Control APIs0.10.0.0
226227KIP-51 - List Connectors REST API0.10.0.0
227228KIP-50 - Move Authorizer to o.a.k.common package0.10.1.0
228229KIP-48 Delegation token support for Kafka1.1.0
229230KIP-45 - Standardize all client sequence interaction on j.u.Collection.0.10.0.0
230231KIP-43: Kafka SASL enhancements0.10.0.0
231232KIP-42: Add Producer and Consumer Interceptors0.10.0.0
232233KIP-41: Consumer Max Records0.10.0.0
233234KIP-40: ListGroups and DescribeGroup0.9.0.0
234235KIP-38: ZooKeeper Authentication0.9.0.0
235236KIP-36 - Rack aware replica assignment0.10.0.0
236237KIP-35 - Retrieving protocol version0.10.0.0
237238KIP-33 - Add a time based log index0.10.1.0
238239KIP-32 - Add timestamps to Kafka message0.10.0.0
239240KIP-31 - Move to relative offsets in compressed message sets0.10.0.0
240241KIP-28 - Add a processor client0.10.0.0
241242KIP-26 - Add Kafka Connect framework for data import/export0.9.0.0
242243KIP-25 - System test improvements0.9.0.0
243244KIP-22 - Expose a Partitioner interface in the new producer0.9.0.0
244245KIP-21 - Dynamic Configuration0.9.0.0 (WIP)
245246KIP-20 Enable log preallocate to improve consume performance under windows and some old Linux file system0.9.0.0
246247KIP-19 - Add a request timeout to NetworkClient0.9.0.0
247248KIP-16 - Automated Replica Lag Tuning0.9.0.0
248249KIP-15 - Add a close method with a timeout in the producer0.9.0.0
249250KIP-13 - Quota Design0.9.0.0
250251KIP-12 - Kafka Sasl/Kerberos and SSL implementation0.9.0.0
251252KIP-11 - Kafka Authorizer design0.9.0.0
252253KIP-8 - Add a flush method to the producer API0.9.0.0
253254KIP-4 - Metadata Protocol Changes0.10.0.0
254255KIP-4 - Command line and centralized administrative operations0.9.0.0, 0.10.0.0, 0.10.1.0
255256KIP-3 - Mirror Maker Enhancement0.9.0.0
256257KIP-2 - Refactor brokers to allow listening on multiple ports and IPs0.9.0.0
257258KIP-1 - Remove support of request.required.acks0.9.0.0

...

KIPComment
KIP-59: Proposal for a kafka broker commandSent emails to Dev discussion group. Work tracked under KAFKA-3663.
KIP-125: ZookeeperConsumerConnector to KafkaConsumer Migration and Rollback 
KIP-131 - Add access to OffsetStorageReader from SourceConnector 
KIP-135 : Send of null key to a compacted topic should throw non-retriable error back to user 
KIP 141 - ProducerRecord & SourceRecord: Add timestamp constructors 
KIP-142: Add ListTopicsRequest to efficiently list all the topics in a cluster 
KIP-148: Add a connect timeout for client 
KIP-158: Kafka Connect should allow source connectors to set topic-specific settings for new topics 
KIP-159: Introducing Rich functions to Streams 
KIP-166 - Add a tool to make amounts of replicas and leaders on brokers balanced 
KIP-169 - Lag-Aware Partition Assignment Strategy 
KIP-178: Size-based log directory selection strategy

 


KIP-185: Make exactly once in order delivery the default producer setting

 


KIP-193: Add SchemaBuilder.from(Schema) 
KIP-199: Add Kafka Connect offset tool 
KIP-201: Rationalising Policy interfaces 
KIP-209: Connection String Support 
KIP-216: IQ should throw different exceptions for different errors 
KIP-217: Expose a timeout to allow an expired ZK session to be re-created 
KIP-221: Enhance KStream with Connecting Topic Creation and Repartition HintDiscussion
KIP-228 Negative record timestamp supportVoting in progress
KIP-234: add support for getting topic defaults from AdminClient 
KIP-236: Interruptible Partition Reassignment Discussion
KIP-240: AdminClient.listReassignments() AdminClient.describeReassignments() 
KIP-242: Mask password in Kafka Connect Rest API response 
KIP-250 Add Support for Quorum-based Producer Acknowledgment 
KIP-252 - Extend ACLs to allow filtering based on ip ranges and subnets 
KIP-253: Support in-order message delivery with partition expansion Discussion
KIP-254: JsonConverter Exception Handeling 
KIP-259: Improve Streams DSL Timestamp Propagation Semantics 
KIP-260: add primary join operation for Stream-Stream join (WIP)Draft
KIP-264: Add a consumer metric to record raw fetch sizeVoting in progress
KIP-271: Add NetworkClient redirectorDiscussion
KIP-273: Kafka to support using ETCD beside ZookeeperDiscussion
KIP-275 - Indicate "isClosing" in the SinkTaskContextVoting in progress
KIP-280: Enhanced log compactionDiscussion

KIP-291: Separating controller connections and requests from the data plane

Accepted
KIP-293 Add new metrics for consumer/replication fetch requestsVoting in progress
KIP-296: Add connector level configurability for producer/consumer client configs Discussion
KIP-300: Add Windowed KTable API in StreamsBuilderDiscussion
KIP-301: Schema Inferencing for JsonConverterDiscussion
KIP-304: Connect runtime mode improvements for container platformsDiscussion
KIP-307: Allow to define custom processor names with KStreams DSLDiscussion
KIP-314: KTable to GlobalKTable Bi-directional JoinDiscussion
KIP-315: Stream Join Sticky AssignorDiscussion
KIP-316: Command-line overrides for ConnectDistributed worker propertiesDiscussion
KIP-317: Add transparent data encryption functionalityDiscussion
KIP-320: Allow fetchers to detect and handle log truncationDiscussion
KIP-325: Extend Consumer Group Command to Show Beginning OffsetsVoting in Progress
KIP-326: Schedulable KTable as Graph sourceDiscussion
KIP-333: Add faster mode of rebalancingDiscussion
KIP-334 - Include partitions in exceptions raised during consumer record deserialization/validation
KIP-335: Consider configurations for KafkaStreams

Discussion

KIP-345: Introduce static membership protocol to reduce consumer rebalancesAccepted
KIP-347: Enable batching in FindCoordinatorRequestDiscussion
KIP-348 Eliminate null from SourceTask#poll()
KIP-350: Allow kafka-topics.sh to take brokerid as parameter to show partitions associated with it
KIP-354: Add a Maximum Log Compaction LagAccepted
KIP-356: Add KafkaConsumer fetch-error-rate and fetch-error-total metricsDiscussion
KIP-360: Improve handling of unknown producerDiscussion
KIP-362: Support Dynamic Session WindowDiscussion
KIP-363: Allow performance tools to print final results to output fileDiscussion
KIP-369: Alternative Partitioner to Support "Always Round-Robin" SelectionDiscussion
KIP-370: Remove Orphan PartitionsDiscussion
KIP-373: Allow users to create delegation tokens for other usersDiscussion
KIP-375: Kafka Clients - make Metadata#TOPIC_EXPIRY_MS configurableDiscussion
KIP-378: Enable Dependency Injection for Kafka Streams handlersDiscussion

KIP-379: Multiple Consumer Group Management

Accepted
KIP-381: Connect: Tell about records that had their offsets flushed in callback

Voting in progress (restarted 18th January 2019, due to no votes in first attempt)

KIP-383:  Pluggable interface for SSL FactoryVoting in progress
KIP-384: Add config for incompatible changes to persistent metadataDiscussion
KIP-385: Avoid throwing away prefetched dataDiscussion
KIP-387: Fair Message Consumption Across Partitions in KafkaConsumer

Discussion

KIP-388: Add observer interface to record request and responseDiscussion
KIP-389: Introduce a configurable consumer group size limitAccepted
KIP-390: Allow fine-grained configuration for compressionDiscussion, JIRA exists with pull-request
KIP-391: Allow Producing with Offsets for Cluster ReplicationDiscussion, JIRA exists with pull-request
KIP-392: Allow consumers to fetch from closest replicaDiscussion
KIP-395: Encypt-then-MAC Delegation token metadata

KIP-396: Add Commit/List Offsets Operations to AdminClient

Discussion
KIP-397: Add methods to override fetch offsets based on timestampDiscussion
KIP-398: Support reading trust store from classpathDiscussion
KIP-399: Extend ProductionExceptionHandler to cover serialization exceptionsDiscussion
KIP-400: Improve exit status in case of errors in ConsoleProducerDiscussion
KIP-401: TransformerSupplier/ProcessorSupplier EnhancementsDiscussion
KIP-403: Increase ProducerPerformance precision by using nanoTimeDraft
KIP-405: Kafka Tiered Storage

Discussion

KIP-406: GlobalStreamThread should honor custom offset policy.Discussion
KIP-407: Kafka Connect support override worker kafka api configuration with connector configuration that post by rest api
KIP-408: Add asynchronous processing to Kafka StreamsDiscussion

KIP-409: Allow creating under-replicated topics and partitions


KIP-410: Add metric for request handler thread pool utilization by request type

Discussion

KIP-411: Make default Kafka Connect worker task client IDs distinct

Discussion
KIP-416: Notify SourceTask of ACK'd offsets, metadataDiscussion
KIP-417: Allow JmxTool to connect to a secured RMI portDiscussion, JIRA exists with pull-request
KIP-418: A method-chaining way to branch KStreamDiscussion, JIRA exists with pull-request
KIP-419: Safely notify Kafka Connect SourceTask is stoppedDiscussion
KIP-421: Support resolving externalized secrets in AbstractConfigDiscussion
KIP-422: Add support for user/client configuration in the Kafka Admin ClientDiscussion, JIRA exists with pull-request
KIP-423: Add JoinReason to Consumer Join Group Protocol

Discussion

KIP-424: Allow suppression of intermediate events based on wall clock timeDiscussion
KIP-426: Persist Broker Id to ZookeeperDiscussion
KIP-429: Kafka Consumer Incremental Rebalance ProtocolDiscussion
KIP-431: Support of printing additional ConsumerRecord fields in DefaultMessageFormatterDiscussion, JIRA exists with pull-request

KIP-432: Additional Broker-Side Opt-In for Default, Unsecure SASL/OAUTHBEARER Implementation

Discussion
KIP-434: Add Replica Fetcher and Log Cleaner Count MetricsDiscussion
KIP-435: Incremental Partition ReassignmentDiscussion
KIP-437: Custom replacement for MaskField SMTDiscussion, JIRA exists with pull-request
KIP-438: Expose task, connector IDs in Connect APIDiscussion
KIP-439: Deprecate Interface WindowStoreIteratorDiscussion
KIP-440: Extend Connect Converter to support headersDiscussion

...

...

KIPComment
KIP-5 - Broker Configuration ManagementSuperseded by KIP-21
KIP-7 - Security - IP Filtering 
KIP-9 - SSL SupportAdopted via KAFKA-1690 but not via this KIP process
KIP-18 - JBOD SupportSuperseded by KIP-112 and KIP-113 
KIP-24 - Remove ISR information from TopicMetadataRequest and add broker level metadata request 
KIP-29 - Add an IsrPropagateIntervalMs configuration to KafkaConfigNo longer need after KAFKA-2722

KIP-34 Add Partitioner Change Listener to Partitioner Interface for Multiple Use Case

Per feedback it is better do this parition() method and avoid Thread Coordination etc.
KIP-80: Kafka Rest Server 
KIP-83 - Allow multiple SASL authenticated Java clients in a single JVM processAfter KIP-85, no interface changes, reduced to KAFKA-4180
KIP-111: Kafka should preserve the Principal generated by the PrincipalBuilder while processing the request received on socket channel, on the broker.Covered by KIP-189
KIP-116: Add State Store Checkpoint Interval ConfigurationCurrently not needed as checkpointing can be done on commit interval.
KIP-127: Pluggable JAAS LoginModule configuration for SSLSimilar functionality can be implemented using a custom PrincipalBuilder.
KIP-132: Augment KStream.print to allow extra parameters in the printed string

Duplicated by KIP-160

KIP-147: Add missing type parameters to StateStoreSupplier factories and KGroupedStream/Table methodsCovered by KIP-182
KIP-165: Extend Interactive Queries for return latest update timestamp per keyCovered by KIP-258
KIP-170: Enhanced TopicCreatePolicy and introduction of TopicDeletePolicySuperseded by KIP-201: Rationalising Policy interfaces
KIP 172: Add regular-expression topic support for sink connectorSuperseded by KIP-215: Add topic regex support for Connect sinks
KIP-179: Change ReassignPartitionsCommand to use AdminClient
KIP-184: Rename LogCleaner and related classes to LogCompactorA lot of configuration change will cause more trouble and doesn't seems to be worth it
KIP 230: Name Windowing JoinsCovered by KIP-372: Naming Repartition Topics for Joins and Grouping
KIP-232: Detect outdated metadata using per-partition leaderEpoch fieldMerged into KIP-320: Allow fetchers to detect and handle log truncation
KIP-246: Connect producers and consumers should inherit worker configsWithdrawn because proposal could not be made backward compatible with existing behavior
KIP-248 - Create New ConfigCommand That Uses The New AdminClientDiscarded by author as it's partly covered in KIP-339 and KIP-422
KIP-262: Metadata should include number of state stores for taskRejected since metadata is no longer required.
KIP-263: Allow broker to skip sanity check of inactive segments on broker startupWithdrawn because the solution we agreed on does not require interface change
KIP-286: producer.send() should not block on metadata updateWithdrawn because the benefit of not having to wait for metadata is probably not worth the complexity added in producer.
KIP-288: [DISCARDED] Consumer.poll() timeout semantic change and new waitForAssignment methodDiscarded in deference to KIP-266
KIP-310: Add a Kafka Source Connector to Kafka ConnectWithdrawn in favor of KIP-382.
KIP-327: Add describe all topics API to AdminClientWithdrawn in-favor of filter support in Metadata API and KIP-142
KIP-344: The auto-generated client id should be passed to MetricsReporterBug fix so KIP not needed
KIP-364: Remove implicit Materialized, Consumed and ProducedSubsumed by KIP-365
KIP-404: Add Kafka Connect configuration parameter for disabling WADL output on OPTIONS request

Discarded, reported as a bug by

Jira
serverASF JIRA
serverId5aa69414-a9e9-3523-82ec-879b028fb15b
keyKAFKA-7759

...