public final class TierPartitionStateEntry
extends com.google.flatbuffers.Table
Modifier and Type | Class and Description |
---|---|
static class |
TierPartitionStateEntry.Vector |
Constructor and Description |
---|
TierPartitionStateEntry() |
Modifier and Type | Method and Description |
---|---|
TierPartitionStateEntry |
__assign(int _i,
ByteBuffer _bb) |
void |
__init(int _i,
ByteBuffer _bb) |
static void |
addBaseOffset(com.google.flatbuffers.FlatBufferBuilder builder,
long baseOffset) |
static void |
addEndOffsetDelta(com.google.flatbuffers.FlatBufferBuilder builder,
int endOffsetDelta) |
static void |
addFirstBatchTimestamp(com.google.flatbuffers.FlatBufferBuilder builder,
long firstBatchTimestamp) |
static void |
addHasAbortedTxns(com.google.flatbuffers.FlatBufferBuilder builder,
boolean hasAbortedTxns) |
static void |
addHasEpochState(com.google.flatbuffers.FlatBufferBuilder builder,
boolean hasEpochState) |
static void |
addHasProducerState(com.google.flatbuffers.FlatBufferBuilder builder,
boolean hasProducerState) |
static void |
addMaxTimestamp(com.google.flatbuffers.FlatBufferBuilder builder,
long maxTimestamp) |
static void |
addObjectId(com.google.flatbuffers.FlatBufferBuilder builder,
int objectIdOffset) |
static void |
addOpaqueData(com.google.flatbuffers.FlatBufferBuilder builder,
int opaqueDataOffset) |
static void |
addSize(com.google.flatbuffers.FlatBufferBuilder builder,
int size) |
static void |
addState(com.google.flatbuffers.FlatBufferBuilder builder,
byte state) |
static void |
addStateBeforeDeletion(com.google.flatbuffers.FlatBufferBuilder builder,
byte stateBeforeDeletion) |
static void |
addStateChangeTimestamp(com.google.flatbuffers.FlatBufferBuilder builder,
long stateChangeTimestamp) |
static void |
addTierEpoch(com.google.flatbuffers.FlatBufferBuilder builder,
int tierEpoch) |
static void |
addUploadType(com.google.flatbuffers.FlatBufferBuilder builder,
byte uploadType) |
static void |
addVersion(com.google.flatbuffers.FlatBufferBuilder builder,
byte version) |
static void |
addVirtualBaseOffsetDelta(com.google.flatbuffers.FlatBufferBuilder builder,
int virtualBaseOffsetDelta) |
long |
baseOffset() |
int |
endOffsetDelta() |
static int |
endTierPartitionStateEntry(com.google.flatbuffers.FlatBufferBuilder builder) |
static void |
finishSizePrefixedTierPartitionStateEntryBuffer(com.google.flatbuffers.FlatBufferBuilder builder,
int offset) |
static void |
finishTierPartitionStateEntryBuffer(com.google.flatbuffers.FlatBufferBuilder builder,
int offset) |
long |
firstBatchTimestamp() |
static TierPartitionStateEntry |
getRootAsTierPartitionStateEntry(ByteBuffer _bb) |
static TierPartitionStateEntry |
getRootAsTierPartitionStateEntry(ByteBuffer _bb,
TierPartitionStateEntry obj) |
boolean |
hasAbortedTxns() |
boolean |
hasEpochState() |
boolean |
hasProducerState() |
long |
maxTimestamp() |
boolean |
mutateBaseOffset(long base_offset) |
boolean |
mutateEndOffsetDelta(int end_offset_delta) |
boolean |
mutateFirstBatchTimestamp(long first_batch_timestamp) |
boolean |
mutateHasAbortedTxns(boolean has_aborted_txns) |
boolean |
mutateHasEpochState(boolean has_epoch_state) |
boolean |
mutateHasProducerState(boolean has_producer_state) |
boolean |
mutateMaxTimestamp(long max_timestamp) |
boolean |
mutateSize(int size) |
boolean |
mutateState(byte state) |
boolean |
mutateStateBeforeDeletion(byte state_before_deletion) |
boolean |
mutateStateChangeTimestamp(long state_change_timestamp) |
boolean |
mutateTierEpoch(int tier_epoch) |
boolean |
mutateUploadType(byte upload_type) |
boolean |
mutateVersion(byte version) |
boolean |
mutateVirtualBaseOffsetDelta(int virtual_base_offset_delta) |
UUID |
objectId() |
UUID |
objectId(UUID obj) |
OpaqueDataField |
opaqueData() |
OpaqueDataField |
opaqueData(OpaqueDataField obj) |
int |
size() |
static void |
startTierPartitionStateEntry(com.google.flatbuffers.FlatBufferBuilder builder) |
byte |
state() |
byte |
stateBeforeDeletion() |
long |
stateChangeTimestamp() |
int |
tierEpoch() |
byte |
uploadType() |
static void |
ValidateVersion() |
byte |
version() |
int |
virtualBaseOffsetDelta() |
__has_identifier, __indirect, __indirect, __offset, __offset, __reset, __reset, __string, __string, __union, __union, __vector_as_bytebuffer, __vector_in_bytebuffer, __vector_len, __vector, compareStrings, compareStrings, getByteBuffer, keysCompare, sortTables
public static void ValidateVersion()
public static TierPartitionStateEntry getRootAsTierPartitionStateEntry(ByteBuffer _bb)
public static TierPartitionStateEntry getRootAsTierPartitionStateEntry(ByteBuffer _bb, TierPartitionStateEntry obj)
public void __init(int _i, ByteBuffer _bb)
public TierPartitionStateEntry __assign(int _i, ByteBuffer _bb)
public byte version()
public boolean mutateVersion(byte version)
public int tierEpoch()
public boolean mutateTierEpoch(int tier_epoch)
public UUID objectId()
public long baseOffset()
public boolean mutateBaseOffset(long base_offset)
public int endOffsetDelta()
public boolean mutateEndOffsetDelta(int end_offset_delta)
public long maxTimestamp()
public boolean mutateMaxTimestamp(long max_timestamp)
public int size()
public boolean mutateSize(int size)
public byte state()
public boolean mutateState(byte state)
public boolean hasEpochState()
public boolean mutateHasEpochState(boolean has_epoch_state)
public boolean hasAbortedTxns()
public boolean mutateHasAbortedTxns(boolean has_aborted_txns)
public boolean hasProducerState()
public boolean mutateHasProducerState(boolean has_producer_state)
public OpaqueDataField opaqueData()
public OpaqueDataField opaqueData(OpaqueDataField obj)
public long firstBatchTimestamp()
public boolean mutateFirstBatchTimestamp(long first_batch_timestamp)
public byte uploadType()
public boolean mutateUploadType(byte upload_type)
public long stateChangeTimestamp()
public boolean mutateStateChangeTimestamp(long state_change_timestamp)
public int virtualBaseOffsetDelta()
public boolean mutateVirtualBaseOffsetDelta(int virtual_base_offset_delta)
public byte stateBeforeDeletion()
public boolean mutateStateBeforeDeletion(byte state_before_deletion)
public static void startTierPartitionStateEntry(com.google.flatbuffers.FlatBufferBuilder builder)
public static void addVersion(com.google.flatbuffers.FlatBufferBuilder builder, byte version)
public static void addTierEpoch(com.google.flatbuffers.FlatBufferBuilder builder, int tierEpoch)
public static void addObjectId(com.google.flatbuffers.FlatBufferBuilder builder, int objectIdOffset)
public static void addBaseOffset(com.google.flatbuffers.FlatBufferBuilder builder, long baseOffset)
public static void addEndOffsetDelta(com.google.flatbuffers.FlatBufferBuilder builder, int endOffsetDelta)
public static void addMaxTimestamp(com.google.flatbuffers.FlatBufferBuilder builder, long maxTimestamp)
public static void addSize(com.google.flatbuffers.FlatBufferBuilder builder, int size)
public static void addState(com.google.flatbuffers.FlatBufferBuilder builder, byte state)
public static void addHasEpochState(com.google.flatbuffers.FlatBufferBuilder builder, boolean hasEpochState)
public static void addHasAbortedTxns(com.google.flatbuffers.FlatBufferBuilder builder, boolean hasAbortedTxns)
public static void addHasProducerState(com.google.flatbuffers.FlatBufferBuilder builder, boolean hasProducerState)
public static void addOpaqueData(com.google.flatbuffers.FlatBufferBuilder builder, int opaqueDataOffset)
public static void addFirstBatchTimestamp(com.google.flatbuffers.FlatBufferBuilder builder, long firstBatchTimestamp)
public static void addUploadType(com.google.flatbuffers.FlatBufferBuilder builder, byte uploadType)
public static void addStateChangeTimestamp(com.google.flatbuffers.FlatBufferBuilder builder, long stateChangeTimestamp)
public static void addVirtualBaseOffsetDelta(com.google.flatbuffers.FlatBufferBuilder builder, int virtualBaseOffsetDelta)
public static void addStateBeforeDeletion(com.google.flatbuffers.FlatBufferBuilder builder, byte stateBeforeDeletion)
public static int endTierPartitionStateEntry(com.google.flatbuffers.FlatBufferBuilder builder)
public static void finishTierPartitionStateEntryBuffer(com.google.flatbuffers.FlatBufferBuilder builder, int offset)
public static void finishSizePrefixedTierPartitionStateEntryBuffer(com.google.flatbuffers.FlatBufferBuilder builder, int offset)