public class GcsTierObjectStore extends Object implements TierObjectStore
TierObjectStore.Backend, TierObjectStore.DataTypePathPrefix, TierObjectStore.FileType, TierObjectStore.ObjectMetadata, TierObjectStore.ObjectStoreMetadata, TierObjectStore.OpaqueData, TierObjectStore.TierStateRestoreSnapshotMetadata
Constructor and Description |
---|
GcsTierObjectStore(org.apache.kafka.common.utils.Time time,
GcsTierObjectStoreConfig config) |
GcsTierObjectStore(org.apache.kafka.common.utils.Time time,
org.apache.kafka.common.metrics.Metrics metrics,
GcsTierObjectStoreConfig config) |
Modifier and Type | Method and Description |
---|---|
void |
close() |
static String |
crc32c(ByteBuffer buf) |
void |
deleteSegment(TierObjectStore.ObjectMetadata objectMetadata) |
TierObjectStore.Backend |
getBackend() |
TierObjectStoreResponse |
getObject(TierObjectStore.ObjectStoreMetadata objectMetadata,
TierObjectStore.FileType fileType,
Integer byteOffsetStart,
Integer byteOffsetEnd) |
TierObjectStore.OpaqueData |
prepPutSegment() |
void |
putObject(TierObjectStore.ObjectStoreMetadata objectMetadata,
File file,
TierObjectStore.FileType fileType) |
void |
putSegment(TierObjectStore.ObjectMetadata objectMetadata,
File segmentData,
File offsetIndexData,
File timestampIndexData,
Optional<File> producerStateSnapshotData,
Optional<ByteBuffer> transactionIndexData,
Optional<ByteBuffer> epochState) |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getObject, getObject
public GcsTierObjectStore(org.apache.kafka.common.utils.Time time, GcsTierObjectStoreConfig config)
public GcsTierObjectStore(org.apache.kafka.common.utils.Time time, org.apache.kafka.common.metrics.Metrics metrics, GcsTierObjectStoreConfig config)
public TierObjectStore.Backend getBackend()
getBackend
in interface TierObjectStore
public TierObjectStoreResponse getObject(TierObjectStore.ObjectStoreMetadata objectMetadata, TierObjectStore.FileType fileType, Integer byteOffsetStart, Integer byteOffsetEnd)
getObject
in interface TierObjectStore
public TierObjectStore.OpaqueData prepPutSegment() throws TierObjectStoreRetriableException, IOException
prepPutSegment
in interface TierObjectStore
TierObjectStoreRetriableException
IOException
public void putSegment(TierObjectStore.ObjectMetadata objectMetadata, File segmentData, File offsetIndexData, File timestampIndexData, Optional<File> producerStateSnapshotData, Optional<ByteBuffer> transactionIndexData, Optional<ByteBuffer> epochState)
putSegment
in interface TierObjectStore
public void putObject(TierObjectStore.ObjectStoreMetadata objectMetadata, File file, TierObjectStore.FileType fileType)
putObject
in interface TierObjectStore
public void deleteSegment(TierObjectStore.ObjectMetadata objectMetadata)
deleteSegment
in interface TierObjectStore
public void close()
close
in interface TierObjectStore
public static String crc32c(ByteBuffer buf)