public final class TierPartitionStateEntry
extends com.google.flatbuffers.Table
Constructor and Description |
---|
TierPartitionStateEntry() |
Modifier and Type | Method and Description |
---|---|
TierPartitionStateEntry |
__assign(int _i,
java.nio.ByteBuffer _bb) |
void |
__init(int _i,
java.nio.ByteBuffer _bb) |
static void |
addBaseOffset(com.google.flatbuffers.FlatBufferBuilder builder,
long baseOffset) |
static void |
addEndOffsetDelta(com.google.flatbuffers.FlatBufferBuilder builder,
int endOffsetDelta) |
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 |
addSize(com.google.flatbuffers.FlatBufferBuilder builder,
int size) |
static void |
addState(com.google.flatbuffers.FlatBufferBuilder builder,
byte state) |
static void |
addTierEpoch(com.google.flatbuffers.FlatBufferBuilder builder,
int tierEpoch) |
static void |
addVersion(com.google.flatbuffers.FlatBufferBuilder builder,
byte version) |
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) |
static TierPartitionStateEntry |
getRootAsTierPartitionStateEntry(java.nio.ByteBuffer _bb) |
static TierPartitionStateEntry |
getRootAsTierPartitionStateEntry(java.nio.ByteBuffer _bb,
TierPartitionStateEntry obj) |
boolean |
hasAbortedTxns() |
boolean |
hasEpochState() |
boolean |
hasProducerState() |
long |
maxTimestamp() |
boolean |
mutateBaseOffset(long baseOffset) |
boolean |
mutateEndOffsetDelta(int endOffsetDelta) |
boolean |
mutateHasAbortedTxns(boolean hasAbortedTxns) |
boolean |
mutateHasEpochState(boolean hasEpochState) |
boolean |
mutateHasProducerState(boolean hasProducerState) |
boolean |
mutateMaxTimestamp(long maxTimestamp) |
boolean |
mutateSize(int size) |
boolean |
mutateState(byte state) |
boolean |
mutateTierEpoch(int tierEpoch) |
boolean |
mutateVersion(byte version) |
UUID |
objectId() |
UUID |
objectId(UUID obj) |
int |
size() |
static void |
startTierPartitionStateEntry(com.google.flatbuffers.FlatBufferBuilder builder) |
byte |
state() |
int |
tierEpoch() |
byte |
version() |
public static TierPartitionStateEntry getRootAsTierPartitionStateEntry(java.nio.ByteBuffer _bb)
public static TierPartitionStateEntry getRootAsTierPartitionStateEntry(java.nio.ByteBuffer _bb, TierPartitionStateEntry obj)
public void __init(int _i, java.nio.ByteBuffer _bb)
public TierPartitionStateEntry __assign(int _i, java.nio.ByteBuffer _bb)
public byte version()
public boolean mutateVersion(byte version)
public int tierEpoch()
public boolean mutateTierEpoch(int tierEpoch)
public UUID objectId()
public long baseOffset()
public boolean mutateBaseOffset(long baseOffset)
public int endOffsetDelta()
public boolean mutateEndOffsetDelta(int endOffsetDelta)
public long maxTimestamp()
public boolean mutateMaxTimestamp(long maxTimestamp)
public int size()
public boolean mutateSize(int size)
public byte state()
public boolean mutateState(byte state)
public boolean hasEpochState()
public boolean mutateHasEpochState(boolean hasEpochState)
public boolean hasAbortedTxns()
public boolean mutateHasAbortedTxns(boolean hasAbortedTxns)
public boolean hasProducerState()
public boolean mutateHasProducerState(boolean hasProducerState)
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 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)