diff --git a/40/generated/connect_rest.yaml b/40/generated/connect_rest.yaml index 69639ddb3..1f2607cc0 100644 --- a/40/generated/connect_rest.yaml +++ b/40/generated/connect_rest.yaml @@ -8,7 +8,7 @@ info: name: Apache 2.0 url: https://www.apache.org/licenses/LICENSE-2.0.html title: Kafka Connect REST API - version: 4.0.0 + version: 4.0.1 paths: /: get: diff --git a/40/generated/protocol_messages.html b/40/generated/protocol_messages.html index 6cb593709..2f86f4a08 100644 --- a/40/generated/protocol_messages.html +++ b/40/generated/protocol_messages.html @@ -843,6 +843,98 @@
Produce Response (Version: 12) => [responses] throttle_time_ms _tagged_fields + responses => name [partition_responses] _tagged_fields + name => COMPACT_STRING + partition_responses => index error_code base_offset log_append_time_ms log_start_offset [record_errors] error_message _tagged_fields + index => INT32 + error_code => INT16 + base_offset => INT64 + log_append_time_ms => INT64 + log_start_offset => INT64 + record_errors => batch_index batch_index_error_message _tagged_fields + batch_index => INT32 + batch_index_error_message => COMPACT_NULLABLE_STRING + error_message => COMPACT_NULLABLE_STRING + throttle_time_ms => INT32 +
Response header version: 1
+Field | +Description | +||||||||||||||||||
---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|
responses | Each produce response. | ||||||||||||||||||
name | The topic name. | ||||||||||||||||||
partition_responses | Each partition that we produced to within the topic. | ||||||||||||||||||
index | The partition index. | ||||||||||||||||||
error_code | The error code, or 0 if there was no error. | ||||||||||||||||||
base_offset | The base offset. | ||||||||||||||||||
log_append_time_ms | The timestamp returned by broker after appending the messages. If CreateTime is used for the topic, the timestamp will be -1. If LogAppendTime is used for the topic, the timestamp will be the broker local time when the messages are appended. | ||||||||||||||||||
log_start_offset | The log start offset. | ||||||||||||||||||
record_errors | The batch indices of records that caused the batch to be dropped. | ||||||||||||||||||
batch_index | The batch index of the record that caused the batch to be dropped. | ||||||||||||||||||
batch_index_error_message | The error message of the record that caused the batch to be dropped. | ||||||||||||||||||
_tagged_fields | The tagged fields | ||||||||||||||||||
error_message | The global error message summarizing the common root cause of the records that caused the batch to be dropped. | ||||||||||||||||||
_tagged_fields |
| ||||||||||||||||||
_tagged_fields | The tagged fields | ||||||||||||||||||
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. | ||||||||||||||||||
_tagged_fields |
|
Fetch Response (Version: 17) => throttle_time_ms error_code session_id [responses] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + session_id => INT32 + responses => topic_id [partitions] _tagged_fields + topic_id => UUID + partitions => partition_index error_code high_watermark last_stable_offset log_start_offset [aborted_transactions] preferred_read_replica records _tagged_fields + partition_index => INT32 + error_code => INT16 + high_watermark => INT64 + last_stable_offset => INT64 + log_start_offset => INT64 + aborted_transactions => producer_id first_offset _tagged_fields + producer_id => INT64 + first_offset => INT64 + preferred_read_replica => INT32 + records => COMPACT_RECORDS +
Response header version: 1
+Field | +Description | +||||||||||||||||||||||||||||||||||||
---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. | ||||||||||||||||||||||||||||||||||||
error_code | The top level response error code. | ||||||||||||||||||||||||||||||||||||
session_id | The fetch session ID, or 0 if this is not part of a fetch session. | ||||||||||||||||||||||||||||||||||||
responses | The response topics. | ||||||||||||||||||||||||||||||||||||
topic_id | The unique topic ID. | ||||||||||||||||||||||||||||||||||||
partitions | The topic partitions. | ||||||||||||||||||||||||||||||||||||
partition_index | The partition index. | ||||||||||||||||||||||||||||||||||||
error_code | The error code, or 0 if there was no fetch error. | ||||||||||||||||||||||||||||||||||||
high_watermark | The current high water mark. | ||||||||||||||||||||||||||||||||||||
last_stable_offset | The last stable offset (or LSO) of the partition. This is the last offset such that the state of all transactional records prior to this offset have been decided (ABORTED or COMMITTED). | ||||||||||||||||||||||||||||||||||||
log_start_offset | The current log start offset. | ||||||||||||||||||||||||||||||||||||
aborted_transactions | The aborted transactions. | ||||||||||||||||||||||||||||||||||||
producer_id | The producer id associated with the aborted transaction. | ||||||||||||||||||||||||||||||||||||
first_offset | The first offset in the aborted transaction. | ||||||||||||||||||||||||||||||||||||
_tagged_fields | The tagged fields | ||||||||||||||||||||||||||||||||||||
preferred_read_replica | The preferred read replica for the consumer to use on its next fetch request. | ||||||||||||||||||||||||||||||||||||
records | The record data. | ||||||||||||||||||||||||||||||||||||
_tagged_fields |
| ||||||||||||||||||||||||||||||||||||
_tagged_fields | The tagged fields | ||||||||||||||||||||||||||||||||||||
_tagged_fields |
|
ListOffsets Response (Version: 10) => throttle_time_ms [topics] _tagged_fields + throttle_time_ms => INT32 + topics => name [partitions] _tagged_fields + name => COMPACT_STRING + partitions => partition_index error_code timestamp offset leader_epoch _tagged_fields + partition_index => INT32 + error_code => INT16 + timestamp => INT64 + offset => INT64 + leader_epoch => INT32 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
topics | Each topic in the response. |
name | The topic name. |
partitions | Each partition in the response. |
partition_index | The partition index. |
error_code | The partition error code, or 0 if there was no error. |
timestamp | The timestamp associated with the returned offset. |
offset | The returned offset. |
leader_epoch | The leader epoch associated with the returned offset. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
Metadata Response (Version: 13) => throttle_time_ms [brokers] cluster_id controller_id [topics] error_code _tagged_fields + throttle_time_ms => INT32 + brokers => node_id host port rack _tagged_fields + node_id => INT32 + host => COMPACT_STRING + port => INT32 + rack => COMPACT_NULLABLE_STRING + cluster_id => COMPACT_NULLABLE_STRING + controller_id => INT32 + topics => error_code name topic_id is_internal [partitions] topic_authorized_operations _tagged_fields + error_code => INT16 + name => COMPACT_NULLABLE_STRING + topic_id => UUID + is_internal => BOOLEAN + partitions => error_code partition_index leader_id leader_epoch [replica_nodes] [isr_nodes] [offline_replicas] _tagged_fields + error_code => INT16 + partition_index => INT32 + leader_id => INT32 + leader_epoch => INT32 + replica_nodes => INT32 + isr_nodes => INT32 + offline_replicas => INT32 + topic_authorized_operations => INT32 + error_code => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
brokers | A list of brokers present in the cluster. |
node_id | The broker ID. |
host | The broker hostname. |
port | The broker port. |
rack | The rack of the broker, or null if it has not been assigned to a rack. |
_tagged_fields | The tagged fields |
cluster_id | The cluster ID that responding broker belongs to. |
controller_id | The ID of the controller broker. |
topics | Each topic in the response. |
error_code | The topic error, or 0 if there was no error. |
name | The topic name. Null for non-existing topics queried by ID. This is never null when ErrorCode is zero. One of Name and TopicId is always populated. |
topic_id | The topic id. Zero for non-existing topics queried by name. This is never zero when ErrorCode is zero. One of Name and TopicId is always populated. |
is_internal | True if the topic is internal. |
partitions | Each partition in the topic. |
error_code | The partition error, or 0 if there was no error. |
partition_index | The partition index. |
leader_id | The ID of the leader broker. |
leader_epoch | The leader epoch of this partition. |
replica_nodes | The set of all nodes that host this partition. |
isr_nodes | The set of nodes that are in sync with the leader for this partition. |
offline_replicas | The set of offline replicas of this partition. |
_tagged_fields | The tagged fields |
topic_authorized_operations | 32-bit bitfield to represent authorized operations for this topic. |
_tagged_fields | The tagged fields |
error_code | The top-level error code, or 0 if there was no error. |
_tagged_fields | The tagged fields |
OffsetCommit Request (Version: 2) => group_id generation_id_or_member_epoch member_id retention_time_ms [topics] group_id => STRING @@ -5040,6 +5381,37 @@OffsetCommit API (Key: 8):
_tagged_fields The tagged fields
OffsetCommit Response (Version: 9) => throttle_time_ms [topics] _tagged_fields + throttle_time_ms => INT32 + topics => name [partitions] _tagged_fields + name => COMPACT_STRING + partitions => partition_index error_code _tagged_fields + partition_index => INT32 + error_code => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
topics | The responses for each topic. |
name | The topic name. |
partitions | The responses for each partition in the topic. |
partition_index | The partition index. |
error_code | The error code, or 0 if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
OffsetFetch Response (Version: 9) => throttle_time_ms [groups] _tagged_fields + throttle_time_ms => INT32 + groups => group_id [topics] error_code _tagged_fields + group_id => COMPACT_STRING + topics => name [partitions] _tagged_fields + name => COMPACT_STRING + partitions => partition_index committed_offset committed_leader_epoch metadata error_code _tagged_fields + partition_index => INT32 + committed_offset => INT64 + committed_leader_epoch => INT32 + metadata => COMPACT_NULLABLE_STRING + error_code => INT16 + error_code => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
groups | The responses per group id. |
group_id | The group ID. |
topics | The responses per topic. |
name | The topic name. |
partitions | The responses per partition. |
partition_index | The partition index. |
committed_offset | The committed message offset. |
committed_leader_epoch | The leader epoch. |
metadata | The partition metadata. |
error_code | The partition-level error code, or 0 if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
error_code | The group-level error code, or 0 if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
FindCoordinator Response (Version: 6) => throttle_time_ms [coordinators] _tagged_fields + throttle_time_ms => INT32 + coordinators => key node_id host port error_code error_message _tagged_fields + key => COMPACT_STRING + node_id => INT32 + host => COMPACT_STRING + port => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
coordinators | Each coordinator result in the response. |
key | The coordinator key. |
node_id | The node id. |
host | The host name. |
port | The port. |
error_code | The error code, or 0 if there was no error. |
error_message | The error message, or null if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
JoinGroup Request (Version: 0) => group_id session_timeout_ms member_id protocol_type [protocols] + group_id => STRING + session_timeout_ms => INT32 + member_id => STRING + protocol_type => STRING + protocols => name metadata + name => STRING + metadata => BYTES +
Request header version: 1
+Field | +Description | +
---|---|
group_id | The group identifier. |
session_timeout_ms | The coordinator considers the consumer dead if it receives no heartbeat after this timeout in milliseconds. |
member_id | The member id assigned by the group coordinator. |
protocol_type | The unique name the for class of protocols implemented by the group we want to join. |
protocols | The list of protocols that the member supports. |
name | The protocol name. |
metadata | The protocol metadata. |
JoinGroup Request (Version: 1) => group_id session_timeout_ms rebalance_timeout_ms member_id protocol_type [protocols] + group_id => STRING + session_timeout_ms => INT32 + rebalance_timeout_ms => INT32 + member_id => STRING + protocol_type => STRING + protocols => name metadata + name => STRING + metadata => BYTES +
Request header version: 1
+Field | +Description | +
---|---|
group_id | The group identifier. |
session_timeout_ms | The coordinator considers the consumer dead if it receives no heartbeat after this timeout in milliseconds. |
rebalance_timeout_ms | The maximum time in milliseconds that the coordinator will wait for each member to rejoin when rebalancing the group. |
member_id | The member id assigned by the group coordinator. |
protocol_type | The unique name the for class of protocols implemented by the group we want to join. |
protocols | The list of protocols that the member supports. |
name | The protocol name. |
metadata | The protocol metadata. |
JoinGroup Request (Version: 2) => group_id session_timeout_ms rebalance_timeout_ms member_id protocol_type [protocols] group_id => STRING session_timeout_ms => INT32 @@ -6112,6 +6629,68 @@JoinGroup API (Key: 11):
JoinGroup Response (Version: 0) => error_code generation_id protocol_name leader member_id [members] + error_code => INT16 + generation_id => INT32 + protocol_name => STRING + leader => STRING + member_id => STRING + members => member_id metadata + member_id => STRING + metadata => BYTES +
Response header version: 0
+Field | +Description | +
---|---|
error_code | The error code, or 0 if there was no error. |
generation_id | The generation ID of the group. |
protocol_name | The group protocol selected by the coordinator. |
leader | The leader of the group. |
member_id | The member ID assigned by the group coordinator. |
members | The group members. |
member_id | The group member ID. |
metadata | The group member metadata. |
JoinGroup Response (Version: 1) => error_code generation_id protocol_name leader member_id [members] + error_code => INT16 + generation_id => INT32 + protocol_name => STRING + leader => STRING + member_id => STRING + members => member_id metadata + member_id => STRING + metadata => BYTES +
Response header version: 0
+Field | +Description | +
---|---|
error_code | The error code, or 0 if there was no error. |
generation_id | The generation ID of the group. |
protocol_name | The group protocol selected by the coordinator. |
leader | The leader of the group. |
member_id | The member ID assigned by the group coordinator. |
members | The group members. |
member_id | The group member ID. |
metadata | The group member metadata. |
JoinGroup Response (Version: 2) => throttle_time_ms error_code generation_id protocol_name leader member_id [members] throttle_time_ms => INT32 error_code => INT16 @@ -6380,6 +6959,53 @@JoinGroup API (Key: 11):
_tagged_fields The tagged fields
JoinGroup Response (Version: 9) => throttle_time_ms error_code generation_id protocol_type protocol_name leader skip_assignment member_id [members] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + generation_id => INT32 + protocol_type => COMPACT_NULLABLE_STRING + protocol_name => COMPACT_NULLABLE_STRING + leader => COMPACT_STRING + skip_assignment => BOOLEAN + member_id => COMPACT_STRING + members => member_id group_instance_id metadata _tagged_fields + member_id => COMPACT_STRING + group_instance_id => COMPACT_NULLABLE_STRING + metadata => COMPACT_BYTES +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
generation_id | The generation ID of the group. |
protocol_type | The group protocol name. |
protocol_name | The group protocol selected by the coordinator. |
leader | The leader of the group. |
skip_assignment | True if the leader must skip running the assignment. |
member_id | The member ID assigned by the group coordinator. |
members | The group members. |
member_id | The group member ID. |
group_instance_id | The unique identifier of the consumer instance provided by end user. |
metadata | The group member metadata. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
Heartbeat Response (Version: 4) => throttle_time_ms error_code _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
_tagged_fields | The tagged fields |
LeaveGroup Response (Version: 5) => throttle_time_ms error_code [members] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + members => member_id group_instance_id error_code _tagged_fields + member_id => COMPACT_STRING + group_instance_id => COMPACT_NULLABLE_STRING + error_code => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
members | List of leaving member responses. |
member_id | The member ID to remove from the group. |
group_instance_id | The group instance ID to remove from the group. |
error_code | The error code, or 0 if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
SyncGroup Response (Version: 5) => throttle_time_ms error_code protocol_type protocol_name assignment _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + protocol_type => COMPACT_NULLABLE_STRING + protocol_name => COMPACT_NULLABLE_STRING + assignment => COMPACT_BYTES +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
protocol_type | The group protocol type. |
protocol_name | The group protocol name. |
assignment | The member assignment. |
_tagged_fields | The tagged fields |
DescribeGroups Response (Version: 6) => throttle_time_ms [groups] _tagged_fields + throttle_time_ms => INT32 + groups => error_code error_message group_id group_state protocol_type protocol_data [members] authorized_operations _tagged_fields + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + group_id => COMPACT_STRING + group_state => COMPACT_STRING + protocol_type => COMPACT_STRING + protocol_data => COMPACT_STRING + members => member_id group_instance_id client_id client_host member_metadata member_assignment _tagged_fields + member_id => COMPACT_STRING + group_instance_id => COMPACT_NULLABLE_STRING + client_id => COMPACT_STRING + client_host => COMPACT_STRING + member_metadata => COMPACT_BYTES + member_assignment => COMPACT_BYTES + authorized_operations => INT32 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
groups | Each described group. |
error_code | The describe error, or 0 if there was no error. |
error_message | The describe error message, or null if there was no error. |
group_id | The group ID string. |
group_state | The group state string, or the empty string. |
protocol_type | The group protocol type, or the empty string. |
protocol_data | The group protocol data, or the empty string. |
members | The group members. |
member_id | The member id. |
group_instance_id | The unique identifier of the consumer instance provided by end user. |
client_id | The client ID used in the member's latest join group request. |
client_host | The client host. |
member_metadata | The metadata corresponding to the current group protocol in use. |
member_assignment | The current assignment provided by the group leader. |
_tagged_fields | The tagged fields |
authorized_operations | 32-bit bitfield to represent authorized operations for this group. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
ListGroups Response (Version: 5) => throttle_time_ms error_code [groups] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + groups => group_id protocol_type group_state group_type _tagged_fields + group_id => COMPACT_STRING + protocol_type => COMPACT_STRING + group_state => COMPACT_STRING + group_type => COMPACT_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
groups | Each group in the response. |
group_id | The group ID. |
protocol_type | The group protocol type. |
group_state | The group state name. |
group_type | The group type name. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
SaslHandshake Response (Version: 1) => error_code [mechanisms] + error_code => INT16 + mechanisms => STRING +
Response header version: 0
+Field | +Description | +
---|---|
error_code | The error code, or 0 if there was no error. |
mechanisms | The mechanisms enabled in the server. |
ApiVersions Request (Version: 0) => @@ -7771,6 +8571,72 @@ApiVersions API (Key: 18):
ApiVersions Response (Version: 4) => error_code [api_keys] throttle_time_ms _tagged_fields + error_code => INT16 + api_keys => api_key min_version max_version _tagged_fields + api_key => INT16 + min_version => INT16 + max_version => INT16 + throttle_time_ms => INT32 +
Response header version: 0
+Field | +Description | +|||||||||||||||||||||||||||||||||||
---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|
error_code | The top-level error code. | |||||||||||||||||||||||||||||||||||
api_keys | The APIs supported by the broker. | |||||||||||||||||||||||||||||||||||
api_key | The API index. | |||||||||||||||||||||||||||||||||||
min_version | The minimum supported version, inclusive. | |||||||||||||||||||||||||||||||||||
max_version | The maximum supported version, inclusive. | |||||||||||||||||||||||||||||||||||
_tagged_fields | The tagged fields | |||||||||||||||||||||||||||||||||||
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. | |||||||||||||||||||||||||||||||||||
_tagged_fields |
|
CreateTopics Response (Version: 7) => throttle_time_ms [topics] _tagged_fields + throttle_time_ms => INT32 + topics => name topic_id error_code error_message num_partitions replication_factor [configs] _tagged_fields + name => COMPACT_STRING + topic_id => UUID + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + num_partitions => INT32 + replication_factor => INT16 + configs => name value read_only config_source is_sensitive _tagged_fields + name => COMPACT_STRING + value => COMPACT_NULLABLE_STRING + read_only => BOOLEAN + config_source => INT8 + is_sensitive => BOOLEAN +
Response header version: 1
+Field | +Description | +||||||
---|---|---|---|---|---|---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. | ||||||
topics | Results for each topic we tried to create. | ||||||
name | The topic name. | ||||||
topic_id | The unique topic ID. | ||||||
error_code | The error code, or 0 if there was no error. | ||||||
error_message | The error message, or null if there was no error. | ||||||
num_partitions | Number of partitions of the topic. | ||||||
replication_factor | Replication factor of the topic. | ||||||
configs | Configuration of the topic. | ||||||
name | The configuration name. | ||||||
value | The configuration value. | ||||||
read_only | True if the configuration is read-only. | ||||||
config_source | The configuration source. | ||||||
is_sensitive | True if this configuration is sensitive. | ||||||
_tagged_fields | The tagged fields | ||||||
_tagged_fields |
| ||||||
_tagged_fields | The tagged fields |
DeleteTopics Response (Version: 6) => throttle_time_ms [responses] _tagged_fields + throttle_time_ms => INT32 + responses => name topic_id error_code error_message _tagged_fields + name => COMPACT_NULLABLE_STRING + topic_id => UUID + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
responses | The results for each topic we tried to delete. |
name | The topic name. |
topic_id | The unique topic ID. |
error_code | The deletion error, or 0 if the deletion succeeded. |
error_message | The error message, or null if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
DeleteRecords Response (Version: 2) => throttle_time_ms [topics] _tagged_fields + throttle_time_ms => INT32 + topics => name [partitions] _tagged_fields + name => COMPACT_STRING + partitions => partition_index low_watermark error_code _tagged_fields + partition_index => INT32 + low_watermark => INT64 + error_code => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
topics | Each topic that we wanted to delete records from. |
name | The topic name. |
partitions | Each partition that we wanted to delete records from. |
partition_index | The partition index. |
low_watermark | The partition low water mark. |
error_code | The deletion error code, or 0 if the deletion succeeded. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
InitProducerId Response (Version: 5) => throttle_time_ms error_code producer_id producer_epoch _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + producer_id => INT64 + producer_epoch => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
producer_id | The current producer id. |
producer_epoch | The current epoch associated with the producer id. |
_tagged_fields | The tagged fields |
OffsetForLeaderEpoch Response (Version: 4) => throttle_time_ms [topics] _tagged_fields + throttle_time_ms => INT32 + topics => topic [partitions] _tagged_fields + topic => COMPACT_STRING + partitions => error_code partition leader_epoch end_offset _tagged_fields + error_code => INT16 + partition => INT32 + leader_epoch => INT32 + end_offset => INT64 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
topics | Each topic we fetched offsets for. |
topic | The topic name. |
partitions | Each partition in the topic we fetched offsets for. |
error_code | The error code 0, or if there was no error. |
partition | The partition index. |
leader_epoch | The leader epoch of the partition. |
end_offset | The end offset of the epoch. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
AddOffsetsToTxn Request (Version: 0) => transactional_id producer_id producer_epoch group_id ++AddPartitionsToTxn Response (Version: 5) => throttle_time_ms error_code [results_by_transaction] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + results_by_transaction => transactional_id [topic_results] _tagged_fields + transactional_id => COMPACT_STRING + topic_results => name [results_by_partition] _tagged_fields + name => COMPACT_STRING + results_by_partition => partition_index partition_error_code _tagged_fields + partition_index => INT32 + partition_error_code => INT16 +Response header version: 1
++
+Field +Description ++ +throttle_time_ms Duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. + +error_code The response top level error code. + +results_by_transaction Results categorized by transactional ID. + +transactional_id The transactional id corresponding to the transaction. + +topic_results The results for each topic. + +name The topic name. + +results_by_partition The results for each partition. + +partition_index The partition indexes. + +partition_error_code The response error code. + +_tagged_fields The tagged fields + +_tagged_fields The tagged fields + +_tagged_fields The tagged fields + +_tagged_fields The tagged fields AddOffsetsToTxn API (Key: 25):
+ +Requests:
++AddOffsetsToTxn Request (Version: 0) => transactional_id producer_id producer_epoch group_id transactional_id => STRING producer_id => INT64 producer_epoch => INT16 @@ -9433,6 +10524,21 @@AddOffsetsToTxn API (Key: 25):_tagged_fields
The tagged fields AddOffsetsToTxn Response (Version: 4) => throttle_time_ms error_code _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 +Response header version: 1
++
+Field +Description ++ +throttle_time_ms Duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. + +error_code The response error code, or 0 if there was no error. + +_tagged_fields The tagged fields EndTxn API (Key: 26):
Requests:
@@ -9626,6 +10732,27 @@EndTxn API (Key: 26):
_tagged_fields The tagged fields
EndTxn Response (Version: 5) => throttle_time_ms error_code producer_id producer_epoch _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + producer_id => INT64 + producer_epoch => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
producer_id | The producer ID. |
producer_epoch | The current epoch associated with the producer. |
_tagged_fields | The tagged fields |
WriteTxnMarkers Response (Version: 1) => [markers] _tagged_fields + markers => producer_id [topics] _tagged_fields + producer_id => INT64 + topics => name [partitions] _tagged_fields + name => COMPACT_STRING + partitions => partition_index error_code _tagged_fields + partition_index => INT32 + error_code => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
markers | The results for writing makers. |
producer_id | The current producer ID in use by the transactional ID. |
topics | The results by topic. |
name | The topic name. |
partitions | The results by partition. |
partition_index | The partition index. |
error_code | The error code, or 0 if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
TxnOffsetCommit Response (Version: 5) => throttle_time_ms [topics] _tagged_fields + throttle_time_ms => INT32 + topics => name [partitions] _tagged_fields + name => COMPACT_STRING + partitions => partition_index error_code _tagged_fields + partition_index => INT32 + error_code => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
topics | The responses for each topic. |
name | The topic name. |
partitions | The responses for each partition in the topic. |
partition_index | The partition index. |
error_code | The error code, or 0 if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
DescribeAcls Response (Version: 3) => throttle_time_ms error_code error_message [resources] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + resources => resource_type resource_name pattern_type [acls] _tagged_fields + resource_type => INT8 + resource_name => COMPACT_STRING + pattern_type => INT8 + acls => principal host operation permission_type _tagged_fields + principal => COMPACT_STRING + host => COMPACT_STRING + operation => INT8 + permission_type => INT8 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
error_message | The error message, or null if there was no error. |
resources | Each Resource that is referenced in an ACL. |
resource_type | The resource type. |
resource_name | The resource name. |
pattern_type | The resource pattern type. |
acls | The ACLs. |
principal | The ACL principal. |
host | The ACL host. |
operation | The ACL operation. |
permission_type | The ACL permission type. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
CreateAcls Response (Version: 3) => throttle_time_ms [results] _tagged_fields + throttle_time_ms => INT32 + results => error_code error_message _tagged_fields + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
results | The results for each ACL creation. |
error_code | The result error, or zero if there was no error. |
error_message | The result message, or null if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
DescribeConfigs Request (Version: 1) => [resources] include_synonyms - resources => resource_type resource_name [configuration_keys] - resource_type => INT8 - resource_name => STRING - configuration_keys => STRING - include_synonyms => BOOLEAN -
Request header version: 1
+DeleteAcls Response (Version: 3) => throttle_time_ms [filter_results] _tagged_fields + throttle_time_ms => INT32 + filter_results => error_code error_message [matching_acls] _tagged_fields + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + matching_acls => error_code error_message resource_type resource_name pattern_type principal host operation permission_type _tagged_fields + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + resource_type => INT8 + resource_name => COMPACT_STRING + pattern_type => INT8 + principal => COMPACT_STRING + host => COMPACT_STRING + operation => INT8 + permission_type => INT8 +
Response header version: 1
Field | Description |
---|---|
resources | The resources whose configurations we want to describe. | throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
resource_type | The resource type. | filter_results | The results for each filter. |
resource_name | The resource name. | error_code | The error code, or 0 if the filter succeeded. |
configuration_keys | The configuration keys to list, or null to list all configuration keys. | error_message | The error message, or null if the filter succeeded. |
include_synonyms | True if we should include all synonyms. |
DescribeConfigs Request (Version: 2) => [resources] include_synonyms - resources => resource_type resource_name [configuration_keys] - resource_type => INT8 - resource_name => STRING - configuration_keys => STRING - include_synonyms => BOOLEAN -
Request header version: 1
-Field | -Description | -
---|---|
matching_acls | The ACLs which matched this filter. |
error_code | The deletion error code, or 0 if the deletion succeeded. |
error_message | The deletion error message, or null if the deletion succeeded. |
resource_type | The ACL resource type. |
resource_name | The ACL resource name. |
pattern_type | The ACL resource pattern type. |
principal | The ACL principal. |
host | The ACL host. |
operation | The ACL operation. |
permission_type | The ACL permission type. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
DescribeConfigs Request (Version: 1) => [resources] include_synonyms + resources => resource_type resource_name [configuration_keys] + resource_type => INT8 + resource_name => STRING + configuration_keys => STRING + include_synonyms => BOOLEAN +
Request header version: 1
+Field | +Description | +
---|---|
resources | The resources whose configurations we want to describe. |
resource_type | The resource type. |
resource_name | The resource name. |
configuration_keys | The configuration keys to list, or null to list all configuration keys. |
include_synonyms | True if we should include all synonyms. |
DescribeConfigs Request (Version: 2) => [resources] include_synonyms + resources => resource_type resource_name [configuration_keys] + resource_type => INT8 + resource_name => STRING + configuration_keys => STRING + include_synonyms => BOOLEAN +
Request header version: 1
+Field | +Description | +
---|---|
resources | The resources whose configurations we want to describe. |
resource_type | The resource type. | The configuration documentation. |
DescribeConfigs Response (Version: 4) => throttle_time_ms [results] _tagged_fields + throttle_time_ms => INT32 + results => error_code error_message resource_type resource_name [configs] _tagged_fields + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + resource_type => INT8 + resource_name => COMPACT_STRING + configs => name value read_only config_source is_sensitive [synonyms] config_type documentation _tagged_fields + name => COMPACT_STRING + value => COMPACT_NULLABLE_STRING + read_only => BOOLEAN + config_source => INT8 + is_sensitive => BOOLEAN + synonyms => name value source _tagged_fields + name => COMPACT_STRING + value => COMPACT_NULLABLE_STRING + source => INT8 + config_type => INT8 + documentation => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
results | The results for each resource. |
error_code | The error code, or 0 if we were able to successfully describe the configurations. |
error_message | The error message, or null if we were able to successfully describe the configurations. |
resource_type | The resource type. |
resource_name | The resource name. |
configs | Each listed configuration. |
name | The configuration name. |
value | The configuration value. |
read_only | True if the configuration is read-only. |
config_source | The configuration source. |
is_sensitive | True if this configuration is sensitive. |
synonyms | The synonyms for this configuration key. |
name | The synonym name. |
value | The synonym value. |
source | The synonym source. |
_tagged_fields | The tagged fields |
config_type | The configuration data type. Type can be one of the following values - BOOLEAN, STRING, INT, SHORT, LONG, DOUBLE, LIST, CLASS, PASSWORD. |
documentation | The configuration documentation. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
AlterConfigs Response (Version: 2) => throttle_time_ms [responses] _tagged_fields + throttle_time_ms => INT32 + responses => error_code error_message resource_type resource_name _tagged_fields + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + resource_type => INT8 + resource_name => COMPACT_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | Duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
responses | The responses for each resource. |
error_code | The resource error code. |
error_message | The resource error message, or null if there was no error. |
resource_type | The resource type. |
resource_name | The resource name. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
AlterReplicaLogDirs Response (Version: 2) => throttle_time_ms [results] _tagged_fields + throttle_time_ms => INT32 + results => topic_name [partitions] _tagged_fields + topic_name => COMPACT_STRING + partitions => partition_index error_code _tagged_fields + partition_index => INT32 + error_code => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | Duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
results | The results for each topic. |
topic_name | The name of the topic. |
partitions | The results for each partition. |
partition_index | The partition index. |
error_code | The error code, or 0 if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
DescribeLogDirs Response (Version: 4) => throttle_time_ms error_code [results] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + results => error_code log_dir [topics] total_bytes usable_bytes _tagged_fields + error_code => INT16 + log_dir => COMPACT_STRING + topics => name [partitions] _tagged_fields + name => COMPACT_STRING + partitions => partition_index partition_size offset_lag is_future_key _tagged_fields + partition_index => INT32 + partition_size => INT64 + offset_lag => INT64 + is_future_key => BOOLEAN + total_bytes => INT64 + usable_bytes => INT64 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
results | The log directories. |
error_code | The error code, or 0 if there was no error. |
log_dir | The absolute log directory path. |
topics | The topics. |
name | The topic name. |
partitions | The partitions. |
partition_index | The partition index. |
partition_size | The size of the log segments in this partition in bytes. |
offset_lag | The lag of the log's LEO w.r.t. partition's HW (if it is the current log for the partition) or current replica's LEO (if it is the future log for the partition). |
is_future_key | True if this log is created by AlterReplicaLogDirsRequest and will replace the current log of the replica in the future. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
total_bytes | The total size in bytes of the volume the log directory is in. |
usable_bytes | The usable size in bytes of the volume the log directory is in. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
SaslAuthenticate Response (Version: 2) => error_code error_message auth_bytes session_lifetime_ms _tagged_fields + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + auth_bytes => COMPACT_BYTES + session_lifetime_ms => INT64 +
Response header version: 1
+Field | +Description | +
---|---|
error_code | The error code, or 0 if there was no error. |
error_message | The error message, or null if there was no error. |
auth_bytes | The SASL authentication bytes from the server, as defined by the SASL mechanism. |
session_lifetime_ms | Number of milliseconds after which only re-authentication over the existing connection to create a new session can occur. |
_tagged_fields | The tagged fields |
CreateDelegationToken Request (Version: 1) => [renewers] max_lifetime_ms ++CreatePartitions Response (Version: 3) => throttle_time_ms [results] _tagged_fields + throttle_time_ms => INT32 + results => name error_code error_message _tagged_fields + name => COMPACT_STRING + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +Response header version: 1
++
+Field +Description ++ +throttle_time_ms The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. + +results The partition creation results for each topic. + +name The topic name. + +error_code The result error, or zero if there was no error. + +error_message The result message, or null if there was no error. + +_tagged_fields The tagged fields + +_tagged_fields The tagged fields CreateDelegationToken API (Key: 38):
+ +Requests:
++CreateDelegationToken Request (Version: 1) => [renewers] max_lifetime_ms renewers => principal_type principal_name principal_type => STRING principal_name => STRING @@ -11756,6 +13310,48 @@CreateDelegationToken API (Key:
_tagged_fields The tagged fields CreateDelegationToken Response (Version: 3) => error_code principal_type principal_name token_requester_principal_type token_requester_principal_name issue_timestamp_ms expiry_timestamp_ms max_timestamp_ms token_id hmac throttle_time_ms _tagged_fields + error_code => INT16 + principal_type => COMPACT_STRING + principal_name => COMPACT_STRING + token_requester_principal_type => COMPACT_STRING + token_requester_principal_name => COMPACT_STRING + issue_timestamp_ms => INT64 + expiry_timestamp_ms => INT64 + max_timestamp_ms => INT64 + token_id => COMPACT_STRING + hmac => COMPACT_BYTES + throttle_time_ms => INT32 +Response header version: 1
++
+Field +Description ++ +error_code The top-level error, or zero if there was no error. + +principal_type The principal type of the token owner. + +principal_name The name of the token owner. + +token_requester_principal_type The principal type of the requester of the token. + +token_requester_principal_name The principal type of the requester of the token. + +issue_timestamp_ms When this token was generated. + +expiry_timestamp_ms When this token expires. + +max_timestamp_ms The maximum lifetime of this token. + +token_id The token UUID. + +hmac HMAC of the delegation token. + +throttle_time_ms The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. + +_tagged_fields The tagged fields RenewDelegationToken API (Key: 39):
Requests:
@@ -11804,6 +13400,24 @@RenewDelegationToken API (Key: 3
throttle_time_ms The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
RenewDelegationToken Response (Version: 2) => error_code expiry_timestamp_ms throttle_time_ms _tagged_fields + error_code => INT16 + expiry_timestamp_ms => INT64 + throttle_time_ms => INT32 +
Response header version: 1
+Field | +Description | +
---|---|
error_code | The error code, or 0 if there was no error. |
expiry_timestamp_ms | The timestamp in milliseconds at which this token expires. |
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
_tagged_fields | The tagged fields |
ExpireDelegationToken Response (Version: 2) => error_code expiry_timestamp_ms throttle_time_ms _tagged_fields + error_code => INT16 + expiry_timestamp_ms => INT64 + throttle_time_ms => INT32 +
Response header version: 1
+Field | +Description | +
---|---|
error_code | The error code, or 0 if there was no error. |
expiry_timestamp_ms | The timestamp in milliseconds at which this token expires. |
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
_tagged_fields | The tagged fields |
DescribeDelegationToken Response (Version: 3) => error_code [tokens] throttle_time_ms _tagged_fields + error_code => INT16 + tokens => principal_type principal_name token_requester_principal_type token_requester_principal_name issue_timestamp expiry_timestamp max_timestamp token_id hmac [renewers] _tagged_fields + principal_type => COMPACT_STRING + principal_name => COMPACT_STRING + token_requester_principal_type => COMPACT_STRING + token_requester_principal_name => COMPACT_STRING + issue_timestamp => INT64 + expiry_timestamp => INT64 + max_timestamp => INT64 + token_id => COMPACT_STRING + hmac => COMPACT_BYTES + renewers => principal_type principal_name _tagged_fields + principal_type => COMPACT_STRING + principal_name => COMPACT_STRING + throttle_time_ms => INT32 +
Response header version: 1
+Field | +Description | +
---|---|
error_code | The error code, or 0 if there was no error. |
tokens | The tokens. |
principal_type | The token principal type. |
principal_name | The token principal name. |
token_requester_principal_type | The principal type of the requester of the token. |
token_requester_principal_name | The principal type of the requester of the token. |
issue_timestamp | The token issue timestamp in milliseconds. |
expiry_timestamp | The token expiry timestamp in milliseconds. |
max_timestamp | The token maximum timestamp length in milliseconds. |
token_id | The token ID. |
hmac | The token HMAC. |
renewers | Those who are able to renew this token before it expires. |
principal_type | The renewer principal type. |
principal_name | The renewer principal name. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
_tagged_fields | The tagged fields |
DeleteGroups Response (Version: 2) => throttle_time_ms [results] _tagged_fields + throttle_time_ms => INT32 + results => group_id error_code _tagged_fields + group_id => COMPACT_STRING + error_code => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
results | The deletion results. |
group_id | The group id. |
error_code | The deletion error, or 0 if the deletion succeeded. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
ElectLeaders Response (Version: 2) => throttle_time_ms error_code [replica_election_results] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + replica_election_results => topic [partition_result] _tagged_fields + topic => COMPACT_STRING + partition_result => partition_id error_code error_message _tagged_fields + partition_id => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The top level response error code. |
replica_election_results | The election results, or an empty array if the requester did not have permission and the request asks for all partitions. |
topic | The topic name. |
partition_result | The results for each partition. |
partition_id | The partition id. |
error_code | The result error, or zero if there was no error. |
error_message | The result message, or null if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
IncrementalAlterConfigs Response (Version: 1) => throttle_time_ms [responses] _tagged_fields + throttle_time_ms => INT32 + responses => error_code error_message resource_type resource_name _tagged_fields + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + resource_type => INT8 + resource_name => COMPACT_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | Duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
responses | The responses for each resource. |
error_code | The resource error code. |
error_message | The resource error message, or null if there was no error. |
resource_type | The resource type. |
resource_name | The resource name. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
ListPartitionReassignments Request (Version: 0) => timeout_ms [topics] _tagged_fields - timeout_ms => INT32 - topics => name [partition_indexes] _tagged_fields ++AlterPartitionReassignments Response (Version: 0) => throttle_time_ms error_code error_message [responses] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + responses => name [partitions] _tagged_fields name => COMPACT_STRING - partition_indexes => INT32 -Request header version: 2
+ partitions => partition_index error_code error_message _tagged_fields + partition_index => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +Response header version: 1
+
Field Description - +timeout_ms The time in ms to wait for the request to complete. throttle_time_ms The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. - +topics The topics to list partition reassignments for, or null to list everything. error_code The top-level error code, or 0 if there was no error. - +name The topic name. error_message The top-level error message, or null if there was no error. - +partition_indexes The partitions to list partition reassignments for. responses The responses to topics to reassign. ++ +name The topic name. + +partitions The responses to partitions to reassign. + +partition_index The partition index. + +error_code The error code for this partition, or 0 if there was no error. + +error_message The error message for this partition, or null if there was no error. + +_tagged_fields The tagged fields + +_tagged_fields The tagged fields + +_tagged_fields The tagged fields ListPartitionReassignments API (Key: 46):
+ +Requests:
+Responses:ListPartitionReassignments Request (Version: 0) => timeout_ms [topics] _tagged_fields + timeout_ms => INT32 + topics => name [partition_indexes] _tagged_fields + name => COMPACT_STRING + partition_indexes => INT32 +Request header version: 2
++
Field +Description ++ +timeout_ms The time in ms to wait for the request to complete. + +topics The topics to list partition reassignments for, or null to list everything. + +name The topic name. + partition_indexes The partitions to list partition reassignments for. _tagged_fields The tagged fields @@ -12373,6 +14192,49 @@ ListPartitionReassignments
+ListPartitionReassignments Response (Version: 0) => throttle_time_ms error_code error_message [topics] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + topics => name [partitions] _tagged_fields + name => COMPACT_STRING + partitions => partition_index [replicas] [adding_replicas] [removing_replicas] _tagged_fields + partition_index => INT32 + replicas => INT32 + adding_replicas => INT32 + removing_replicas => INT32 +Response header version: 1
++
+Field +Description ++ +throttle_time_ms The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. + +error_code The top-level error code, or 0 if there was no error. + +error_message The top-level error message, or null if there was no error. + +topics The ongoing reassignments for each topic. + +name The topic name. + +partitions The ongoing reassignments for each partition. + +partition_index The index of the partition. + +replicas The current replica set. + +adding_replicas The set of replicas we are currently adding. + +removing_replicas The set of replicas we are currently removing. + +_tagged_fields The tagged fields + +_tagged_fields The tagged fields + +_tagged_fields The tagged fields OffsetDelete API (Key: 47):
Requests:
@@ -12399,6 +14261,34 @@OffsetDelete API (Key: 47):
OffsetDelete Response (Version: 0) => error_code throttle_time_ms [topics] + error_code => INT16 + throttle_time_ms => INT32 + topics => name [partitions] + name => STRING + partitions => partition_index error_code + partition_index => INT32 + error_code => INT16 +
Response header version: 0
+Field | +Description | +
---|---|
error_code | The top-level error code, or 0 if there was no error. |
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
topics | The responses for each topic. |
name | The topic name. |
partitions | The responses for each partition in the topic. |
partition_index | The partition index. |
error_code | The error code, or 0 if there was no error. |
DescribeClientQuotas Response (Version: 1) => throttle_time_ms error_code error_message [entries] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + entries => [entity] [values] _tagged_fields + entity => entity_type entity_name _tagged_fields + entity_type => COMPACT_STRING + entity_name => COMPACT_NULLABLE_STRING + values => key value _tagged_fields + key => COMPACT_STRING + value => FLOAT64 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or `0` if the quota description succeeded. |
error_message | The error message, or `null` if the quota description succeeded. |
entries | A result entry. |
entity | The quota entity description. |
entity_type | The entity type. |
entity_name | The entity name, or null if the default. |
_tagged_fields | The tagged fields |
values | The quota values for the entity. |
key | The quota configuration key. |
value | The quota configuration value. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
AlterClientQuotas Response (Version: 1) => throttle_time_ms [entries] _tagged_fields + throttle_time_ms => INT32 + entries => error_code error_message [entity] _tagged_fields + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + entity => entity_type entity_name _tagged_fields + entity_type => COMPACT_STRING + entity_name => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
entries | The quota configuration entries to alter. |
error_code | The error code, or `0` if the quota alteration succeeded. |
error_message | The error message, or `null` if the quota alteration succeeded. |
entity | The quota entity to alter. |
entity_type | The entity type. |
entity_name | The name of the entity, or null if the default. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
DescribeUserScramCredentials Response (Version: 0) => throttle_time_ms error_code error_message [results] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + results => user error_code error_message [credential_infos] _tagged_fields + user => COMPACT_STRING + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + credential_infos => mechanism iterations _tagged_fields + mechanism => INT8 + iterations => INT32 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The message-level error code, 0 except for user authorization or infrastructure issues. |
error_message | The message-level error message, if any. |
results | The results for descriptions, one per user. |
user | The user name. |
error_code | The user-level error code. |
error_message | The user-level error message, if any. |
credential_infos | The mechanism and related information associated with the user's SCRAM credentials. |
mechanism | The SCRAM mechanism. |
iterations | The number of iterations used in the SCRAM credential. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
AlterUserScramCredentials Response (Version: 0) => throttle_time_ms [results] _tagged_fields + throttle_time_ms => INT32 + results => user error_code error_message _tagged_fields + user => COMPACT_STRING + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
results | The results for deletions and alterations, one per affected user. |
user | The user name. |
error_code | The error code. |
error_message | The error message, if any. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
UpdateFeatures Request (Version: 0) => timeout_ms [feature_updates] _tagged_fields - timeout_ms => INT32 - feature_updates => feature max_version_level allow_downgrade _tagged_fields - feature => COMPACT_STRING - max_version_level => INT16 - allow_downgrade => BOOLEAN -
Request header version: 2
+DescribeQuorum Response (Version: 2) => error_code error_message [topics] [nodes] _tagged_fields + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + topics => topic_name [partitions] _tagged_fields + topic_name => COMPACT_STRING + partitions => partition_index error_code error_message leader_id leader_epoch high_watermark [current_voters] [observers] _tagged_fields + partition_index => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + leader_id => INT32 + leader_epoch => INT32 + high_watermark => INT64 + current_voters => replica_id replica_directory_id log_end_offset last_fetch_timestamp last_caught_up_timestamp _tagged_fields + replica_id => INT32 + replica_directory_id => UUID + log_end_offset => INT64 + last_fetch_timestamp => INT64 + last_caught_up_timestamp => INT64 + observers => replica_id replica_directory_id log_end_offset last_fetch_timestamp last_caught_up_timestamp _tagged_fields + replica_id => INT32 + replica_directory_id => UUID + log_end_offset => INT64 + last_fetch_timestamp => INT64 + last_caught_up_timestamp => INT64 + nodes => node_id [listeners] _tagged_fields + node_id => INT32 + listeners => name host port _tagged_fields + name => COMPACT_STRING + host => COMPACT_STRING + port => UINT16 +
Response header version: 1
Field | Description |
---|---|
timeout_ms | How long to wait in milliseconds before timing out the request. | error_code | The top level error code. |
feature_updates | The list of updates to finalized features. | error_message | The error message, or null if there was no error. |
feature | The name of the finalized feature to be updated. | topics | The response from the describe quorum API. |
max_version_level | The new maximum version level for the finalized feature. A value >= 1 is valid. A value < 1, is special, and can be used to request the deletion of the finalized feature. | topic_name | The topic name. | +
partitions | The partition data. |
partition_index | The partition index. |
error_code | The partition error code. |
error_message | The error message, or null if there was no error. |
leader_id | The ID of the current leader or -1 if the leader is unknown. |
leader_epoch | The latest known leader epoch. |
high_watermark | The high water mark. |
current_voters | The current voters of the partition. |
replica_id | The ID of the replica. |
replica_directory_id | The replica directory ID of the replica. |
log_end_offset | The last known log end offset of the follower or -1 if it is unknown. |
last_fetch_timestamp | The last known leader wall clock time time when a follower fetched from the leader. This is reported as -1 both for the current leader or if it is unknown for a voter. |
last_caught_up_timestamp | The leader wall clock append time of the offset for which the follower made the most recent fetch request. This is reported as the current time for the leader and -1 if unknown for a voter. |
_tagged_fields | The tagged fields |
observers | The observers of the partition. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
nodes | The nodes in the quorum. |
node_id | The ID of the associated node. |
listeners | The listeners of this controller. |
name | The name of the endpoint. |
host | The hostname. |
port | The port. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
UpdateFeatures Request (Version: 0) => timeout_ms [feature_updates] _tagged_fields + timeout_ms => INT32 + feature_updates => feature max_version_level allow_downgrade _tagged_fields + feature => COMPACT_STRING + max_version_level => INT16 + allow_downgrade => BOOLEAN +
Request header version: 2
+Field | +Description | +
---|---|
timeout_ms | How long to wait in milliseconds before timing out the request. |
feature_updates | The list of updates to finalized features. |
feature | The name of the finalized feature to be updated. |
max_version_level | The new maximum version level for the finalized feature. A value >= 1 is valid. A value < 1, is special, and can be used to request the deletion of the finalized feature. |
allow_downgrade | DEPRECATED in version 1 (see DowngradeType). When set to true, the finalized feature version level is allowed to be downgraded/deleted. The downgrade request will fail if the new maximum version level is a value that's not lower than the existing maximum finalized version level. |
_tagged_fields | The tagged fields |
UpdateFeatures Response (Version: 2) => throttle_time_ms error_code error_message _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The top-level error code, or `0` if there was no top-level error. |
error_message | The top-level error message, or `null` if there was no top-level error. |
_tagged_fields | The tagged fields |
DescribeCluster Response (Version: 2) => throttle_time_ms error_code error_message endpoint_type cluster_id controller_id [brokers] cluster_authorized_operations _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + endpoint_type => INT8 + cluster_id => COMPACT_STRING + controller_id => INT32 + brokers => broker_id host port rack is_fenced _tagged_fields + broker_id => INT32 + host => COMPACT_STRING + port => INT32 + rack => COMPACT_NULLABLE_STRING + is_fenced => BOOLEAN + cluster_authorized_operations => INT32 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The top-level error code, or 0 if there was no error. |
error_message | The top-level error message, or null if there was no error. |
endpoint_type | The endpoint type that was described. 1=brokers, 2=controllers. |
cluster_id | The cluster ID that responding broker belongs to. |
controller_id | The ID of the controller broker. |
brokers | Each broker in the response. |
broker_id | The broker ID. |
host | The broker hostname. |
port | The broker port. |
rack | The rack of the broker, or null if it has not been assigned to a rack. |
is_fenced | Whether the broker is fenced |
_tagged_fields | The tagged fields |
cluster_authorized_operations | 32-bit bitfield to represent authorized operations for this cluster. |
_tagged_fields | The tagged fields |
DescribeProducers Response (Version: 0) => throttle_time_ms [topics] _tagged_fields + throttle_time_ms => INT32 + topics => name [partitions] _tagged_fields + name => COMPACT_STRING + partitions => partition_index error_code error_message [active_producers] _tagged_fields + partition_index => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + active_producers => producer_id producer_epoch last_sequence last_timestamp coordinator_epoch current_txn_start_offset _tagged_fields + producer_id => INT64 + producer_epoch => INT32 + last_sequence => INT32 + last_timestamp => INT64 + coordinator_epoch => INT32 + current_txn_start_offset => INT64 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
topics | Each topic in the response. |
name | The topic name. |
partitions | Each partition in the response. |
partition_index | The partition index. |
error_code | The partition error code, or 0 if there was no error. |
error_message | The partition error message, which may be null if no additional details are available. |
active_producers | The active producers for the partition. |
producer_id | The producer id. |
producer_epoch | The producer epoch. |
last_sequence | The last sequence number sent by the producer. |
last_timestamp | The last timestamp sent by the producer. |
coordinator_epoch | The current epoch of the producer group. |
current_txn_start_offset | The current transaction start offset of the producer. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
UnregisterBroker Response (Version: 0) => throttle_time_ms error_code error_message _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | Duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
error_message | The top-level error message, or `null` if there was no top-level error. |
_tagged_fields | The tagged fields |
DescribeTransactions Response (Version: 0) => throttle_time_ms [transaction_states] _tagged_fields + throttle_time_ms => INT32 + transaction_states => error_code transactional_id transaction_state transaction_timeout_ms transaction_start_time_ms producer_id producer_epoch [topics] _tagged_fields + error_code => INT16 + transactional_id => COMPACT_STRING + transaction_state => COMPACT_STRING + transaction_timeout_ms => INT32 + transaction_start_time_ms => INT64 + producer_id => INT64 + producer_epoch => INT16 + topics => topic [partitions] _tagged_fields + topic => COMPACT_STRING + partitions => INT32 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
transaction_states | The current state of the transaction. |
error_code | The error code. |
transactional_id | The transactional id. |
transaction_state | The current transaction state of the producer. |
transaction_timeout_ms | The timeout in milliseconds for the transaction. |
transaction_start_time_ms | The start time of the transaction in milliseconds. |
producer_id | The current producer id associated with the transaction. |
producer_epoch | The current epoch associated with the producer id. |
topics | The set of partitions included in the current transaction (if active). When a transaction is preparing to commit or abort, this will include only partitions which do not have markers. |
topic | The topic name. |
partitions | The partition ids included in the current transaction. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
ConsumerGroupHeartbeat Request (Version: 0) => group_id member_id member_epoch instance_id rack_id rebalance_timeout_ms [subscribed_topic_names] server_assignor [topic_partitions] _tagged_fields - group_id => COMPACT_STRING - member_id => COMPACT_STRING - member_epoch => INT32 - instance_id => COMPACT_NULLABLE_STRING - rack_id => COMPACT_NULLABLE_STRING - rebalance_timeout_ms => INT32 - subscribed_topic_names => COMPACT_STRING - server_assignor => COMPACT_NULLABLE_STRING - topic_partitions => topic_id [partitions] _tagged_fields - topic_id => UUID - partitions => INT32 -
Request header version: 2
+ListTransactions Response (Version: 1) => throttle_time_ms error_code [unknown_state_filters] [transaction_states] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + unknown_state_filters => COMPACT_STRING + transaction_states => transactional_id producer_id transaction_state _tagged_fields + transactional_id => COMPACT_STRING + producer_id => INT64 + transaction_state => COMPACT_STRING +
Response header version: 1
Field | Description |
---|---|
group_id | The group identifier. | throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. | +
error_code | The error code, or 0 if there was no error. |
unknown_state_filters | Set of state filters provided in the request which were unknown to the transaction coordinator. |
transaction_states | The current state of the transaction for the transactional id. |
transactional_id | The transactional id. |
producer_id | The producer id. |
transaction_state | The current transaction state of the producer. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
ConsumerGroupHeartbeat Request (Version: 0) => group_id member_id member_epoch instance_id rack_id rebalance_timeout_ms [subscribed_topic_names] server_assignor [topic_partitions] _tagged_fields + group_id => COMPACT_STRING + member_id => COMPACT_STRING + member_epoch => INT32 + instance_id => COMPACT_NULLABLE_STRING + rack_id => COMPACT_NULLABLE_STRING + rebalance_timeout_ms => INT32 + subscribed_topic_names => COMPACT_STRING + server_assignor => COMPACT_NULLABLE_STRING + topic_partitions => topic_id [partitions] _tagged_fields + topic_id => UUID + partitions => INT32 +
Request header version: 2
+Field | +Description | +
---|---|
group_id | The group identifier. |
member_id | The member id generated by the consumer. The member id must be kept during the entire lifetime of the consumer process. |
_tagged_fields | The tagged fields |
ConsumerGroupHeartbeat Response (Version: 1) => throttle_time_ms error_code error_message member_id member_epoch heartbeat_interval_ms assignment _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + member_id => COMPACT_NULLABLE_STRING + member_epoch => INT32 + heartbeat_interval_ms => INT32 + assignment => [topic_partitions] _tagged_fields + topic_partitions => topic_id [partitions] _tagged_fields + topic_id => UUID + partitions => INT32 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The top-level error code, or 0 if there was no error. |
error_message | The top-level error message, or null if there was no error. |
member_id | The member id is generated by the consumer starting from version 1, while in version 0, it can be provided by users or generated by the group coordinator. |
member_epoch | The member epoch. |
heartbeat_interval_ms | The heartbeat interval in milliseconds. |
assignment | null if not provided; the assignment otherwise. |
topic_partitions | The partitions assigned to the member that can be used immediately. |
topic_id | The topic ID. |
partitions | The partitions. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
ConsumerGroupDescribe Response (Version: 1) => throttle_time_ms [groups] _tagged_fields + throttle_time_ms => INT32 + groups => error_code error_message group_id group_state group_epoch assignment_epoch assignor_name [members] authorized_operations _tagged_fields + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + group_id => COMPACT_STRING + group_state => COMPACT_STRING + group_epoch => INT32 + assignment_epoch => INT32 + assignor_name => COMPACT_STRING + members => member_id instance_id rack_id member_epoch client_id client_host [subscribed_topic_names] subscribed_topic_regex assignment target_assignment member_type _tagged_fields + member_id => COMPACT_STRING + instance_id => COMPACT_NULLABLE_STRING + rack_id => COMPACT_NULLABLE_STRING + member_epoch => INT32 + client_id => COMPACT_STRING + client_host => COMPACT_STRING + subscribed_topic_names => COMPACT_STRING + subscribed_topic_regex => COMPACT_NULLABLE_STRING + assignment => [topic_partitions] _tagged_fields + topic_partitions => topic_id topic_name [partitions] _tagged_fields + topic_id => UUID + topic_name => COMPACT_STRING + partitions => INT32 + target_assignment => [topic_partitions] _tagged_fields + topic_partitions => topic_id topic_name [partitions] _tagged_fields + topic_id => UUID + topic_name => COMPACT_STRING + partitions => INT32 + member_type => INT8 + authorized_operations => INT32 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
groups | Each described group. |
error_code | The describe error, or 0 if there was no error. |
error_message | The top-level error message, or null if there was no error. |
group_id | The group ID string. |
group_state | The group state string, or the empty string. |
group_epoch | The group epoch. |
assignment_epoch | The assignment epoch. |
assignor_name | The selected assignor. |
members | The members. |
member_id | The member ID. |
instance_id | The member instance ID. |
rack_id | The member rack ID. |
member_epoch | The current member epoch. |
client_id | The client ID. |
client_host | The client host. |
subscribed_topic_names | The subscribed topic names. |
subscribed_topic_regex | the subscribed topic regex otherwise or null of not provided. |
assignment | The current assignment. |
topic_partitions | The assigned topic-partitions to the member. |
topic_id | The topic ID. |
topic_name | The topic name. |
partitions | The partitions. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
target_assignment | The target assignment. |
member_type | -1 for unknown. 0 for classic member. +1 for consumer member. |
_tagged_fields | The tagged fields |
authorized_operations | 32-bit bitfield to represent authorized operations for this group. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
GetTelemetrySubscriptions Response (Version: 0) => throttle_time_ms error_code client_instance_id subscription_id [accepted_compression_types] push_interval_ms telemetry_max_bytes delta_temporality [requested_metrics] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + client_instance_id => UUID + subscription_id => INT32 + accepted_compression_types => INT8 + push_interval_ms => INT32 + telemetry_max_bytes => INT32 + delta_temporality => BOOLEAN + requested_metrics => COMPACT_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
client_instance_id | Assigned client instance id if ClientInstanceId was 0 in the request, else 0. |
subscription_id | Unique identifier for the current subscription set for this client instance. |
accepted_compression_types | Compression types that broker accepts for the PushTelemetryRequest. |
push_interval_ms | Configured push interval, which is the lowest configured interval in the current subscription set. |
telemetry_max_bytes | The maximum bytes of binary data the broker accepts in PushTelemetryRequest. |
delta_temporality | Flag to indicate monotonic/counter metrics are to be emitted as deltas or cumulative values. |
requested_metrics | Requested metrics prefix string match. Empty array: No metrics subscribed, Array[0] empty string: All metrics subscribed. |
_tagged_fields | The tagged fields |
PushTelemetry Response (Version: 0) => throttle_time_ms error_code _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
_tagged_fields | The tagged fields |
ListClientMetricsResources Response (Version: 0) => throttle_time_ms error_code [client_metrics_resources] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + client_metrics_resources => name _tagged_fields + name => COMPACT_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
client_metrics_resources | Each client metrics resource in the response. |
name | The resource name. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
ShareGroupHeartbeat Request (Version: 0) => group_id member_id member_epoch rack_id [subscribed_topic_names] _tagged_fields - group_id => COMPACT_STRING - member_id => COMPACT_STRING - member_epoch => INT32 - rack_id => COMPACT_NULLABLE_STRING - subscribed_topic_names => COMPACT_STRING -
This version of the request is unstable.
Request header version: 2
-Field | -Description | -
---|---|
group_id | The group identifier. |
member_id | The member id. |
member_epoch | The current member epoch; 0 to join the group; -1 to leave the group. |
rack_id | null if not provided or if it didn't change since the last heartbeat; the rack ID of consumer otherwise. |
subscribed_topic_names | null if it didn't change since the last heartbeat; the subscribed topic names otherwise. |
Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
topics | Each topic in the response. |
error_code | The topic error, or 0 if there was no error. |
name | The topic name. |
topic_id | The topic id. |
is_internal | True if the topic is internal. |
partitions | Each partition in the topic. |
error_code | The partition error, or 0 if there was no error. |
partition_index | The partition index. |
leader_id | The ID of the leader broker. |
leader_epoch | The leader epoch of this partition. |
replica_nodes | The set of all nodes that host this partition. |
isr_nodes | The set of nodes that are in sync with the leader for this partition. |
eligible_leader_replicas | The new eligible leader replicas otherwise. |
last_known_elr | The last known ELR. |
offline_replicas | The set of offline replicas of this partition. |
_tagged_fields | The tagged fields |
topic_authorized_operations | 32-bit bitfield to represent authorized operations for this topic. |
_tagged_fields | The tagged fields |
next_cursor | The next topic and partition index to fetch details for. |
topic_name | The name for the first topic to process. |
partition_index | The partition index to start with. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
ShareGroupHeartbeat Request (Version: 0) => group_id member_id member_epoch rack_id [subscribed_topic_names] _tagged_fields + group_id => COMPACT_STRING + member_id => COMPACT_STRING + member_epoch => INT32 + rack_id => COMPACT_NULLABLE_STRING + subscribed_topic_names => COMPACT_STRING +
This version of the request is unstable.
Request header version: 2
+Field | +Description | +
---|---|
group_id | The group identifier. |
member_id | The member id. |
member_epoch | The current member epoch; 0 to join the group; -1 to leave the group. |
rack_id | null if not provided or if it didn't change since the last heartbeat; the rack ID of consumer otherwise. |
subscribed_topic_names | null if it didn't change since the last heartbeat; the subscribed topic names otherwise. |
_tagged_fields | The tagged fields |
ShareGroupHeartbeat Response (Version: 0) => throttle_time_ms error_code error_message member_id member_epoch heartbeat_interval_ms assignment _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + member_id => COMPACT_NULLABLE_STRING + member_epoch => INT32 + heartbeat_interval_ms => INT32 + assignment => [topic_partitions] _tagged_fields + topic_partitions => topic_id [partitions] _tagged_fields + topic_id => UUID + partitions => INT32 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The top-level error code, or 0 if there was no error. |
error_message | The top-level error message, or null if there was no error. |
member_id | The member ID is generated by the consumer and provided by the consumer for all requests. |
member_epoch | The member epoch. |
heartbeat_interval_ms | The heartbeat interval in milliseconds. |
assignment | null if not provided; the assignment otherwise. |
topic_partitions | The partitions assigned to the member. |
topic_id | The topic ID. |
partitions | The partitions. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
ShareGroupDescribe Response (Version: 0) => throttle_time_ms [groups] _tagged_fields + throttle_time_ms => INT32 + groups => error_code error_message group_id group_state group_epoch assignment_epoch assignor_name [members] authorized_operations _tagged_fields + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + group_id => COMPACT_STRING + group_state => COMPACT_STRING + group_epoch => INT32 + assignment_epoch => INT32 + assignor_name => COMPACT_STRING + members => member_id rack_id member_epoch client_id client_host [subscribed_topic_names] assignment _tagged_fields + member_id => COMPACT_STRING + rack_id => COMPACT_NULLABLE_STRING + member_epoch => INT32 + client_id => COMPACT_STRING + client_host => COMPACT_STRING + subscribed_topic_names => COMPACT_STRING + assignment => [topic_partitions] _tagged_fields + topic_partitions => topic_id topic_name [partitions] _tagged_fields + topic_id => UUID + topic_name => COMPACT_STRING + partitions => INT32 + authorized_operations => INT32 +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
groups | Each described group. |
error_code | The describe error, or 0 if there was no error. |
error_message | The top-level error message, or null if there was no error. |
group_id | The group ID string. |
group_state | The group state string, or the empty string. |
group_epoch | The group epoch. |
assignment_epoch | The assignment epoch. |
assignor_name | The selected assignor. |
members | The members. |
member_id | The member ID. |
rack_id | The member rack ID. |
member_epoch | The current member epoch. |
client_id | The client ID. |
client_host | The client host. |
subscribed_topic_names | The subscribed topic names. |
assignment | The current assignment. |
topic_partitions | The assigned topic-partitions to the member. |
topic_id | The topic ID. |
topic_name | The topic name. |
partitions | The partitions. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
authorized_operations | 32-bit bitfield to represent authorized operations for this group. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
ShareFetch Response (Version: 0) => throttle_time_ms error_code error_message [responses] [node_endpoints] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + responses => topic_id [partitions] _tagged_fields + topic_id => UUID + partitions => partition_index error_code error_message acknowledge_error_code acknowledge_error_message current_leader records [acquired_records] _tagged_fields + partition_index => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + acknowledge_error_code => INT16 + acknowledge_error_message => COMPACT_NULLABLE_STRING + current_leader => leader_id leader_epoch _tagged_fields + leader_id => INT32 + leader_epoch => INT32 + records => COMPACT_RECORDS + acquired_records => first_offset last_offset delivery_count _tagged_fields + first_offset => INT64 + last_offset => INT64 + delivery_count => INT16 + node_endpoints => node_id host port rack _tagged_fields + node_id => INT32 + host => COMPACT_STRING + port => INT32 + rack => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The top-level response error code. |
error_message | The top-level error message, or null if there was no error. |
responses | The response topics. |
topic_id | The unique topic ID. |
partitions | The topic partitions. |
partition_index | The partition index. |
error_code | The fetch error code, or 0 if there was no fetch error. |
error_message | The fetch error message, or null if there was no fetch error. |
acknowledge_error_code | The acknowledge error code, or 0 if there was no acknowledge error. |
acknowledge_error_message | The acknowledge error message, or null if there was no acknowledge error. |
current_leader | The current leader of the partition. |
leader_id | The ID of the current leader or -1 if the leader is unknown. |
leader_epoch | The latest known leader epoch. |
_tagged_fields | The tagged fields |
records | The record data. |
acquired_records | The acquired records. |
first_offset | The earliest offset in this batch of acquired records. |
last_offset | The last offset of this batch of acquired records. |
delivery_count | The delivery count of this batch of acquired records. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
node_endpoints | Endpoints for all current leaders enumerated in PartitionData with error NOT_LEADER_OR_FOLLOWER. |
node_id | The ID of the associated node. |
host | The node's hostname. |
topic_id | The unique topic ID. | port | The node's port. |
partitions | The partitions indexes to forget. | rack | The rack of the node, or null if it has not been assigned to a rack. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
ShareAcknowledge Response (Version: 0) => throttle_time_ms error_code error_message [responses] [node_endpoints] _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + responses => topic_id [partitions] _tagged_fields + topic_id => UUID + partitions => partition_index error_code error_message current_leader _tagged_fields + partition_index => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + current_leader => leader_id leader_epoch _tagged_fields + leader_id => INT32 + leader_epoch => INT32 + node_endpoints => node_id host port rack _tagged_fields + node_id => INT32 + host => COMPACT_STRING + port => INT32 + rack => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The top level response error code. |
error_message | The top-level error message, or null if there was no error. |
responses | The response topics. |
topic_id | The unique topic ID. |
partitions | The topic partitions. |
partition_index | The partition index. |
error_code | The error code, or 0 if there was no error. |
error_message | The error message, or null if there was no error. |
current_leader | The current leader of the partition. |
leader_id | The ID of the current leader or -1 if the leader is unknown. |
leader_epoch | The latest known leader epoch. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
node_endpoints | Endpoints for all current leaders enumerated in PartitionData with error NOT_LEADER_OR_FOLLOWER. |
node_id | The ID of the associated node. |
host | The node's hostname. |
port | The node's port. |
rack | The rack of the node, or null if it has not been assigned to a rack. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
AddRaftVoter Response (Version: 0) => throttle_time_ms error_code error_message _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
error_message | The error message, or null if there was no error. |
_tagged_fields | The tagged fields |
RemoveRaftVoter Response (Version: 0) => throttle_time_ms error_code error_message _tagged_fields + throttle_time_ms => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
throttle_time_ms | The duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. |
error_code | The error code, or 0 if there was no error. |
error_message | The error message, or null if there was no error. |
_tagged_fields | The tagged fields |
InitializeShareGroupState Response (Version: 0) => [results] _tagged_fields + results => topic_id [partitions] _tagged_fields + topic_id => UUID + partitions => partition error_code error_message _tagged_fields + partition => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
results | The initialization results. |
topic_id | The topic identifier. |
partitions | The results for the partitions. |
partition | The partition index. |
error_code | The error code, or 0 if there was no error. |
error_message | The error message, or null if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
ReadShareGroupState Response (Version: 0) => [results] _tagged_fields + results => topic_id [partitions] _tagged_fields + topic_id => UUID + partitions => partition error_code error_message state_epoch start_offset [state_batches] _tagged_fields + partition => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + state_epoch => INT32 + start_offset => INT64 + state_batches => first_offset last_offset delivery_state delivery_count _tagged_fields + first_offset => INT64 + last_offset => INT64 + delivery_state => INT8 + delivery_count => INT16 +
Response header version: 1
+Field | +Description | +
---|---|
results | The read results. |
topic_id | The topic identifier. |
partitions | The results for the partitions. |
partition | The partition index. |
error_code | The error code, or 0 if there was no error. |
error_message | The error message, or null if there was no error. |
state_epoch | The state epoch for this share-partition. |
start_offset | The share-partition start offset, which can be -1 if it is not yet initialized. |
state_batches | The state batches for this share-partition. |
first_offset | The base offset of this state batch. |
last_offset | The last offset of this state batch. |
delivery_state | The state - 0:Available,2:Acked,4:Archived. |
delivery_count | The delivery count. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
WriteShareGroupState Response (Version: 0) => [results] _tagged_fields + results => topic_id [partitions] _tagged_fields + topic_id => UUID + partitions => partition error_code error_message _tagged_fields + partition => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
results | The write results. |
topic_id | The topic identifier. |
partitions | The results for the partitions. |
partition | The partition index. |
error_code | The error code, or 0 if there was no error. |
error_message | The error message, or null if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
DeleteShareGroupState Response (Version: 0) => [results] _tagged_fields + results => topic_id [partitions] _tagged_fields + topic_id => UUID + partitions => partition error_code error_message _tagged_fields + partition => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +
Response header version: 1
+Field | +Description | +
---|---|
results | The delete results. |
topic_id | The topic identifier. |
partitions | The results for the partitions. |
partition | The partition index. |
error_code | The error code, or 0 if there was no error. |
error_message | The error message, or null if there was no error. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
ReadShareGroupStateSummary Response (Version: 0) => [results] _tagged_fields + results => topic_id [partitions] _tagged_fields + topic_id => UUID + partitions => partition error_code error_message state_epoch start_offset _tagged_fields + partition => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING + state_epoch => INT32 + start_offset => INT64 +
Response header version: 1
+Field | +Description | +
---|---|
results | The read results. |
topic_id | The topic identifier. |
partitions | The results for the partitions. |
partition | The partition index. |
error_code | The error code, or 0 if there was no error. |
error_message | The error message, or null if there was no error. |
state_epoch | The state epoch of the share-partition. |
start_offset | The share-partition start offset. |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
_tagged_fields | The tagged fields |
To enable tiered storage for a topic, set this configuration as true. You can not disable this config once it is enabled. It will be provided in future versions.
+To enable tiered storage for a topic, set this configuration to true. To disable tiered storage for a topic that has it enabled, set this configuration to false. When disabling, you must also set remote.log.delete.on.disable
to true.