public class TransactionLogValue extends Object implements org.apache.kafka.common.protocol.ApiMessage
Modifier and Type | Class and Description |
---|---|
static class |
TransactionLogValue.PartitionsSchema |
Modifier and Type | Field and Description |
---|---|
static short |
HIGHEST_SUPPORTED_VERSION |
static short |
LOWEST_SUPPORTED_VERSION |
static org.apache.kafka.common.protocol.types.Schema |
SCHEMA_0 |
static org.apache.kafka.common.protocol.types.Schema[] |
SCHEMAS |
Constructor and Description |
---|
TransactionLogValue() |
TransactionLogValue(org.apache.kafka.common.protocol.Readable _readable,
short _version) |
TransactionLogValue(org.apache.kafka.common.protocol.Readable _readable,
short _version,
org.apache.kafka.common.protocol.MessageContext _context) |
Modifier and Type | Method and Description |
---|---|
void |
addSize(org.apache.kafka.common.protocol.MessageSizeAccumulator _size,
org.apache.kafka.common.protocol.ObjectSerializationCache _cache,
short _version,
org.apache.kafka.common.protocol.MessageContext _context) |
short |
apiKey() |
TransactionLogValue |
duplicate() |
boolean |
equals(Object obj) |
int |
hashCode() |
short |
highestSupportedVersion() |
short |
lowestSupportedVersion() |
short |
producerEpoch() |
long |
producerId() |
void |
read(org.apache.kafka.common.protocol.Readable _readable,
short _version,
org.apache.kafka.common.protocol.MessageContext _context) |
TransactionLogValue |
setProducerEpoch(short v) |
TransactionLogValue |
setProducerId(long v) |
TransactionLogValue |
setTransactionLastUpdateTimestampMs(long v) |
TransactionLogValue |
setTransactionPartitions(List<TransactionLogValue.PartitionsSchema> v) |
TransactionLogValue |
setTransactionStartTimestampMs(long v) |
TransactionLogValue |
setTransactionStatus(byte v) |
TransactionLogValue |
setTransactionTimeoutMs(int v) |
String |
toString() |
long |
transactionLastUpdateTimestampMs() |
List<TransactionLogValue.PartitionsSchema> |
transactionPartitions() |
long |
transactionStartTimestampMs() |
byte |
transactionStatus() |
int |
transactionTimeoutMs() |
List<org.apache.kafka.common.protocol.types.RawTaggedField> |
unknownTaggedFields() |
void |
write(org.apache.kafka.common.protocol.Writable _writable,
org.apache.kafka.common.protocol.ObjectSerializationCache _cache,
short _version,
org.apache.kafka.common.protocol.MessageContext _context) |
public static final org.apache.kafka.common.protocol.types.Schema SCHEMA_0
public static final org.apache.kafka.common.protocol.types.Schema[] SCHEMAS
public static final short LOWEST_SUPPORTED_VERSION
public static final short HIGHEST_SUPPORTED_VERSION
public TransactionLogValue(org.apache.kafka.common.protocol.Readable _readable, short _version)
public TransactionLogValue(org.apache.kafka.common.protocol.Readable _readable, short _version, org.apache.kafka.common.protocol.MessageContext _context)
public TransactionLogValue()
public short apiKey()
apiKey
in interface org.apache.kafka.common.protocol.ApiMessage
public short lowestSupportedVersion()
lowestSupportedVersion
in interface org.apache.kafka.common.protocol.Message
public short highestSupportedVersion()
highestSupportedVersion
in interface org.apache.kafka.common.protocol.Message
public void read(org.apache.kafka.common.protocol.Readable _readable, short _version, org.apache.kafka.common.protocol.MessageContext _context)
read
in interface org.apache.kafka.common.protocol.Message
public void write(org.apache.kafka.common.protocol.Writable _writable, org.apache.kafka.common.protocol.ObjectSerializationCache _cache, short _version, org.apache.kafka.common.protocol.MessageContext _context)
write
in interface org.apache.kafka.common.protocol.Message
public void addSize(org.apache.kafka.common.protocol.MessageSizeAccumulator _size, org.apache.kafka.common.protocol.ObjectSerializationCache _cache, short _version, org.apache.kafka.common.protocol.MessageContext _context)
addSize
in interface org.apache.kafka.common.protocol.Message
public TransactionLogValue duplicate()
duplicate
in interface org.apache.kafka.common.protocol.Message
public long producerId()
public short producerEpoch()
public int transactionTimeoutMs()
public byte transactionStatus()
public List<TransactionLogValue.PartitionsSchema> transactionPartitions()
public long transactionLastUpdateTimestampMs()
public long transactionStartTimestampMs()
public List<org.apache.kafka.common.protocol.types.RawTaggedField> unknownTaggedFields()
unknownTaggedFields
in interface org.apache.kafka.common.protocol.Message
public TransactionLogValue setProducerId(long v)
public TransactionLogValue setProducerEpoch(short v)
public TransactionLogValue setTransactionTimeoutMs(int v)
public TransactionLogValue setTransactionStatus(byte v)
public TransactionLogValue setTransactionPartitions(List<TransactionLogValue.PartitionsSchema> v)
public TransactionLogValue setTransactionLastUpdateTimestampMs(long v)
public TransactionLogValue setTransactionStartTimestampMs(long v)