package
api
Type Members
-
case class
ConsumerMetadataRequest
(group: String, versionId: Short, correlationId: Int, clientId: String) extends RequestOrResponse with Product with Serializable
-
case class
ConsumerMetadataResponse
(coordinatorOpt: Option[Broker], errorCode: Short, correlationId: Int) extends RequestOrResponse with Product with Serializable
-
case class
ControlledShutdownRequest
(versionId: Short, correlationId: Int, brokerId: Int) extends RequestOrResponse with Product with Serializable
-
case class
ControlledShutdownResponse
(correlationId: Int, errorCode: Short, partitionsRemaining: Set[TopicAndPartition]) extends RequestOrResponse with Product with Serializable
-
case class
FetchRequest
(versionId: Short, correlationId: Int, clientId: String, replicaId: Int, maxWait: Int, minBytes: Int, requestInfo: Map[TopicAndPartition, PartitionFetchInfo]) extends RequestOrResponse with Product with Serializable
-
-
case class
FetchResponse
(correlationId: Int, data: Map[TopicAndPartition, FetchResponsePartitionData]) extends RequestOrResponse with Product with Serializable
-
case class
FetchResponsePartitionData
(error: Short, hw: Long, messages: MessageSet) extends Product with Serializable
-
-
case class
HeartbeatRequestAndHeader
(versionId: Short, correlationId: Int, clientId: String, body: HeartbeatRequest) extends GenericRequestAndHeader with Product with Serializable
-
case class
HeartbeatResponseAndHeader
(correlationId: Int, body: HeartbeatResponse) extends GenericResponseAndHeader with Product with Serializable
-
case class
JoinGroupRequestAndHeader
(versionId: Short, correlationId: Int, clientId: String, body: JoinGroupRequest) extends GenericRequestAndHeader with Product with Serializable
-
case class
JoinGroupResponseAndHeader
(correlationId: Int, body: JoinGroupResponse) extends GenericResponseAndHeader with Product with Serializable
-
case class
LeaderAndIsr
(leader: Int, leaderEpoch: Int, isr: List[Int], zkVersion: Int) extends Product with Serializable
-
case class
LeaderAndIsrRequest
(versionId: Short, correlationId: Int, clientId: String, controllerId: Int, controllerEpoch: Int, partitionStateInfos: Map[(String, Int), PartitionStateInfo], leaders: Set[Broker]) extends RequestOrResponse with Product with Serializable
-
case class
LeaderAndIsrResponse
(correlationId: Int, responseMap: Map[(String, Int), Short], errorCode: Short) extends RequestOrResponse with Product with Serializable
-
case class
OffsetCommitRequest
(groupId: String, requestInfo: Map[TopicAndPartition, OffsetAndMetadata], versionId: Short, correlationId: Int, clientId: String, groupGenerationId: Int, consumerId: String) extends RequestOrResponse with Product with Serializable
-
case class
OffsetCommitResponse
(commitStatus: Map[TopicAndPartition, Short], correlationId: Int) extends RequestOrResponse with Product with Serializable
-
case class
OffsetFetchRequest
(groupId: String, requestInfo: Seq[TopicAndPartition], versionId: Short, correlationId: Int, clientId: String) extends RequestOrResponse with Product with Serializable
-
case class
OffsetFetchResponse
(requestInfo: Map[TopicAndPartition, OffsetMetadataAndError], correlationId: Int) extends RequestOrResponse with Product with Serializable
-
case class
OffsetRequest
(requestInfo: Map[TopicAndPartition, PartitionOffsetRequestInfo], versionId: Short, correlationId: Int, clientId: String, replicaId: Int) extends RequestOrResponse with Product with Serializable
-
case class
OffsetResponse
(correlationId: Int, partitionErrorAndOffsets: Map[TopicAndPartition, PartitionOffsetsResponse]) extends RequestOrResponse with Product with Serializable
-
-
case class
PartitionFetchInfo
(offset: Long, fetchSize: Int) extends Product with Serializable
-
case class
PartitionMetadata
(partitionId: Int, leader: Option[Broker], replicas: Seq[Broker], isr: Seq[Broker], errorCode: Short) extends Logging with Product with Serializable
-
case class
PartitionOffsetRequestInfo
(time: Long, maxNumOffsets: Int) extends Product with Serializable
-
case class
PartitionOffsetsResponse
(error: Short, offsets: Seq[Long]) extends Product with Serializable
-
case class
PartitionStateInfo
(leaderIsrAndControllerEpoch: LeaderIsrAndControllerEpoch, allReplicas: Set[Int]) extends Product with Serializable
-
case class
ProducerRequest
(versionId: Short, correlationId: Int, clientId: String, requiredAcks: Short, ackTimeoutMs: Int, data: Map[TopicAndPartition, ByteBufferMessageSet]) extends RequestOrResponse with Product with Serializable
-
case class
ProducerResponse
(correlationId: Int, status: Map[TopicAndPartition, ProducerResponseStatus]) extends RequestOrResponse with Product with Serializable
-
case class
ProducerResponseStatus
(error: Short, offset: Long) extends Product with Serializable
-
-
case class
StopReplicaRequest
(versionId: Short, correlationId: Int, clientId: String, controllerId: Int, controllerEpoch: Int, deletePartitions: Boolean, partitions: Set[TopicAndPartition]) extends RequestOrResponse with Product with Serializable
-
case class
StopReplicaResponse
(correlationId: Int, responseMap: Map[TopicAndPartition, Short], errorCode: Short) extends RequestOrResponse with Product with Serializable
-
case class
TopicData
(topic: String, partitionData: Map[Int, FetchResponsePartitionData]) extends Product with Serializable
-
-
case class
TopicMetadata
(topic: String, partitionsMetadata: Seq[PartitionMetadata], errorCode: Short) extends Logging with Product with Serializable
-
case class
TopicMetadataRequest
(versionId: Short, correlationId: Int, clientId: String, topics: Seq[String]) extends RequestOrResponse with Product with Serializable
-
case class
TopicMetadataResponse
(brokers: Seq[Broker], topicsMetadata: Seq[TopicMetadata], correlationId: Int) extends RequestOrResponse with Product with Serializable
-
case class
UpdateMetadataRequest
(versionId: Short, correlationId: Int, clientId: String, controllerId: Int, controllerEpoch: Int, partitionStateInfos: Map[TopicAndPartition, PartitionStateInfo], aliveBrokers: Set[Broker]) extends RequestOrResponse with Product with Serializable
-
case class
UpdateMetadataResponse
(correlationId: Int, errorCode: Short) extends RequestOrResponse with Product with Serializable