Skip navigation links
A B C D E F H I L M O P R S T U V 

A

addRemoteLogSegmentMetadata(RemoteLogSegmentMetadata) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
This method is used to add RemoteLogSegmentMetadata asynchronously with the containing RemoteLogSegmentId into RemoteLogMetadataManager.

B

brokerId() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogMetadata
 

C

copyLogSegmentData(RemoteLogSegmentMetadata, LogSegmentData) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
Copies the given LogSegmentData provided for the given remoteLogSegmentMetadata.
createWithUpdates(RemoteLogSegmentMetadataUpdate) - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
Creates a new RemoteLogSegmentMetadata applying the given rlsmUpdate on this instance.

D

deleteLogSegmentData(RemoteLogSegmentMetadata) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
Deletes the resources associated with the given remoteLogSegmentMetadata.

E

endOffset() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
 
equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
 
equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
 
equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
 
equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
 
equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
 
eventTimestampMs() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogMetadata
 

F

fetchIndex(RemoteLogSegmentMetadata, RemoteStorageManager.IndexType) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
Returns the index for the respective log segment of RemoteLogSegmentMetadata.
fetchLogSegment(RemoteLogSegmentMetadata, int) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
Returns the remote log segment data file/object as InputStream for the given RemoteLogSegmentMetadata starting from the given startPosition.
fetchLogSegment(RemoteLogSegmentMetadata, int, int) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
Returns the remote log segment data file/object as InputStream for the given RemoteLogSegmentMetadata starting from the given startPosition.
forId(byte) - Static method in enum org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
 
forId(byte) - Static method in enum org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
 

H

hashCode() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
 
hashCode() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
 
hashCode() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
 
hashCode() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
 
hashCode() - Method in class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
 
highestOffsetForEpoch(TopicIdPartition, int) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
Returns the highest log offset of topic partition for the given leader epoch in remote storage.

I

id() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
 
id() - Method in enum org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
 
id() - Method in enum org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
 
isValidTransition(RemoteLogSegmentState, RemoteLogSegmentState) - Static method in enum org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
 
isValidTransition(RemotePartitionDeleteState, RemotePartitionDeleteState) - Static method in enum org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
 

L

leaderEpochIndex() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
 
listRemoteLogSegments(TopicIdPartition) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
Returns all the remote log segment metadata of the given topicIdPartition.
listRemoteLogSegments(TopicIdPartition, int) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
Returns iterator of remote log segment metadata, sorted by RemoteLogSegmentMetadata.startOffset() in ascending order which contains the given leader epoch.
logSegment() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
 
LogSegmentData - Class in org.apache.kafka.server.log.remote.storage
This represents all the required data and indexes for a specific log segment that needs to be stored in the remote storage.
LogSegmentData(Path, Path, Path, Optional<Path>, Path, ByteBuffer) - Constructor for class org.apache.kafka.server.log.remote.storage.LogSegmentData
Creates a LogSegmentData instance with data and indexes.

M

maxTimestampMs() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
 

O

offsetIndex() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
 
onPartitionLeadershipChanges(Set<TopicIdPartition>, Set<TopicIdPartition>) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
This method is invoked only when there are changes in leadership of the topic partitions that this broker is responsible for.
onStopPartitions(Set<TopicIdPartition>) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
This method is invoked only when the topic partitions are stopped on this broker.
org.apache.kafka.server.log.remote.storage - package org.apache.kafka.server.log.remote.storage
 

P

producerSnapshotIndex() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
 
putRemotePartitionDeleteMetadata(RemotePartitionDeleteMetadata) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
This method is used to update the metadata about remote partition delete event asynchronously.

R

RemoteLogMetadata - Class in org.apache.kafka.server.log.remote.storage
Base class for remote log metadata objects like RemoteLogSegmentMetadata, RemoteLogSegmentMetadataUpdate, and RemotePartitionDeleteMetadata.
RemoteLogMetadata(int, long) - Constructor for class org.apache.kafka.server.log.remote.storage.RemoteLogMetadata
 
RemoteLogMetadataManager - Interface in org.apache.kafka.server.log.remote.storage
This interface provides storing and fetching remote log segment metadata with strongly consistent semantics.
RemoteLogSegmentId - Class in org.apache.kafka.server.log.remote.storage
This class represents a universally unique identifier associated to a topic partition's log segment.
RemoteLogSegmentId(TopicIdPartition, Uuid) - Constructor for class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
 
remoteLogSegmentId() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
 
remoteLogSegmentId() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
 
remoteLogSegmentMetadata(TopicIdPartition, int, long) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
Returns RemoteLogSegmentMetadata if it exists for the given topic partition containing the offset with the given leader-epoch for the offset, else returns Optional.empty().
RemoteLogSegmentMetadata - Class in org.apache.kafka.server.log.remote.storage
It describes the metadata about a topic partition's remote log segment in the remote storage.
RemoteLogSegmentMetadata(RemoteLogSegmentId, long, long, long, int, long, int, RemoteLogSegmentState, Map<Integer, Long>) - Constructor for class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
Creates an instance with the given metadata of remote log segment.
RemoteLogSegmentMetadata(RemoteLogSegmentId, long, long, long, int, long, int, Map<Integer, Long>) - Constructor for class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
Creates an instance with the given metadata of remote log segment and its state as RemoteLogSegmentState.COPY_SEGMENT_STARTED.
RemoteLogSegmentMetadataUpdate - Class in org.apache.kafka.server.log.remote.storage
It describes the metadata update about the log segment in the remote storage.
RemoteLogSegmentMetadataUpdate(RemoteLogSegmentId, long, RemoteLogSegmentState, int) - Constructor for class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
 
RemoteLogSegmentState - Enum in org.apache.kafka.server.log.remote.storage
This enum indicates the state of the remote log segment.
RemotePartitionDeleteMetadata - Class in org.apache.kafka.server.log.remote.storage
This class represents the metadata about the remote partition.
RemotePartitionDeleteMetadata(TopicIdPartition, RemotePartitionDeleteState, long, int) - Constructor for class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
Creates an instance of this class with the given metadata.
RemotePartitionDeleteState - Enum in org.apache.kafka.server.log.remote.storage
This enum indicates the deletion state of the remote topic partition.
RemoteResourceNotFoundException - Exception in org.apache.kafka.server.log.remote.storage
Exception thrown when a resource is not found on the remote storage.
RemoteResourceNotFoundException(String) - Constructor for exception org.apache.kafka.server.log.remote.storage.RemoteResourceNotFoundException
 
RemoteResourceNotFoundException(Throwable) - Constructor for exception org.apache.kafka.server.log.remote.storage.RemoteResourceNotFoundException
 
RemoteResourceNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.server.log.remote.storage.RemoteResourceNotFoundException
 
RemoteStorageException - Exception in org.apache.kafka.server.log.remote.storage
Exception thrown when there is a remote storage error.
RemoteStorageException(String) - Constructor for exception org.apache.kafka.server.log.remote.storage.RemoteStorageException
 
RemoteStorageException(String, Throwable) - Constructor for exception org.apache.kafka.server.log.remote.storage.RemoteStorageException
 
RemoteStorageException(Throwable) - Constructor for exception org.apache.kafka.server.log.remote.storage.RemoteStorageException
 
RemoteStorageManager - Interface in org.apache.kafka.server.log.remote.storage
This interface provides the lifecycle of remote log segments that includes copy, fetch, and delete from remote storage.
RemoteStorageManager.IndexType - Enum in org.apache.kafka.server.log.remote.storage
Type of the index file.

S

segmentLeaderEpochs() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
 
segmentSizeInBytes() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
 
startOffset() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
 
state() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
Returns the current state of this remote log segment.
state() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
It represents the state of the remote log segment.
state() - Method in class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
It represents the state of the remote partition.

T

timeIndex() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
 
topicIdPartition() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogMetadata
 
topicIdPartition() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
 
topicIdPartition() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
 
topicIdPartition() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
 
topicIdPartition() - Method in class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
 
toString() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
 
toString() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
 
toString() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
 
toString() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
 
toString() - Method in class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
 
transactionIndex() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
 

U

updateRemoteLogSegmentMetadata(RemoteLogSegmentMetadataUpdate) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
This method is used to update the RemoteLogSegmentMetadata asynchronously.

V

valueOf(String) - Static method in enum org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.server.log.remote.storage.RemoteStorageManager.IndexType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.server.log.remote.storage.RemoteStorageManager.IndexType
Returns an array containing the constants of this enum type, in the order they are declared.
A B C D E F H I L M O P R S T U V 
Skip navigation links