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

A

addPartitionUpdate(PushReplicationEvent<?>, PushSession) - Method in class io.confluent.kafka.replication.push.buffer.BufferingPartitionDataBuilder
Processes any type of partition update event.
addTransitionRecords(PushReplicationEvent<PushReplicationEvent.TransitionRecordsPayload>, PushSession) - Method in class io.confluent.kafka.replication.push.buffer.BufferingPartitionDataBuilder
Consumes a PushReplicationEvent.Type.TRANSITION_RECORDS event for this partition replica.
appendOffset() - Method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent.RecordsPayload
 

B

BufferingAppendRecordsBuilder - Class in io.confluent.kafka.replication.push.buffer
Used to consume incoming PushReplicationEvents for a given destination broker and (eventually) to build an AppendRecords out of them.
BufferingAppendRecordsBuilder(int, long, ReplicationConfig, RefCountingMemoryTracker<MemoryRecords>, Time) - Constructor for class io.confluent.kafka.replication.push.buffer.BufferingAppendRecordsBuilder
 
BufferingPartitionDataBuilder - Class in io.confluent.kafka.replication.push.buffer
Used to consume incoming PushReplicationEvents for a given partition replica and (eventually) to build a AppendRecordsRequestData.PartitionData out of them.
BufferingPartitionDataBuilder(TopicIdPartition, PushSession, long) - Constructor for class io.confluent.kafka.replication.push.buffer.BufferingPartitionDataBuilder
Creates a new builder for the given partition with the given restriction for the maximum amount of memory-consuming records that can be buffered in it.
BufferingPartitionDataBuilder.PartitionRecords - Class in io.confluent.kafka.replication.push.buffer
A MultiBufferRecords that can send the buffers of multiple memory records in a single org.apache.kafka.common.network.Send.
buffers() - Method in class io.confluent.kafka.replication.push.buffer.BufferingPartitionDataBuilder.PartitionRecords
 
build() - Method in class io.confluent.kafka.replication.push.buffer.BufferingAppendRecordsBuilder
Creates an AppendRecordsRequestData from all the buffered data in the builder.
build() - Method in class io.confluent.kafka.replication.push.buffer.BufferingPartitionDataBuilder
Builds a AppendRecordsRequestData.PartitionData out of the consumed push replication events for this partition replica with the given leader epoch and replication session ID.

C

canTransitionTo(ReplicationState.Mode, long) - Method in class io.confluent.kafka.replication.push.ReplicationStateMetadata
 
clear() - Method in class io.confluent.kafka.replication.push.buffer.BufferingAppendRecordsBuilder
Clears all data buffered in the partitions builders of this request builder, including untracking all buffered MemoryRecords.
close() - Method in class io.confluent.kafka.replication.push.buffer.RefCountingMemoryTracker
Closing the tracker clears up its internal state.
CONFLUENT_REPLICATION_PREFIX - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
countDown(K) - Method in class io.confluent.kafka.replication.push.buffer.RefCountingMemoryTracker
Decrements with 1 the ref count of the given ref-counted memory-occupying object.

D

defineReplicationConfigs() - Static method in class io.confluent.kafka.replication.push.ReplicationConfig
 
destinationBrokerEpoch() - Method in class io.confluent.kafka.replication.push.buffer.BufferingAppendRecordsBuilder
 
destinationBrokerId() - Method in class io.confluent.kafka.replication.push.buffer.BufferingAppendRecordsBuilder
The ID of the destination broker for which this builder creates AppendRecords requests.

E

equals(Object) - Method in class io.confluent.kafka.replication.push.ReplicationStateMetadata
 

F

FINAL_REPLICATION_SESSION_ID - Static variable in class io.confluent.kafka.replication.push.ReplicationStateMetadata
The final replication session ID.
forHighWatermarkUpdate(TopicIdPartition, int, long) - Static method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent
Creates a new event of type PushReplicationEvent.Type.HWM_UPDATE with its payload being an PushReplicationEvent.OffsetPayload containing the updated high watermark.
forLogStartOffsetUpdate(TopicIdPartition, int, long) - Static method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent
Creates a new event of type PushReplicationEvent.Type.LSO_UPDATE with its payload being an PushReplicationEvent.OffsetPayload containing the updated log start offset.
forRecords(TopicIdPartition, int, AbstractRecords, long, long) - Static method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent
Creates a new event of type either PushReplicationEvent.Type.MEMORY_RECORDS or PushReplicationEvent.Type.FILE_RECORDS with its payload being a PushReplicationEvent.RecordsPayload containing the given records and offsets.
forStartPush(TopicIdPartition, int, PushSession) - Static method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent
Creates a new event of type PushReplicationEvent.Type.START_PUSH with its payload being the given PushSession.
forStopPush(TopicIdPartition, int) - Static method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent
Creates a new event of type PushReplicationEvent.Type.STOP_PUSH with its payload being an CompletableFuture containing the future that will be used as the result of the push replication stop operation.
forTransitionRecords(PushReplicationEvent<PushReplicationEvent.RecordsPayload>, CompletableFuture<Void>) - Static method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent
Creates a new event of type PushReplicationEvent.Type.TRANSITION_RECORDS from a given PushReplicationEvent.Type.FILE_RECORDS event and a completable future.

G

getPusher(TopicIdPartition, int) - Method in class io.confluent.kafka.replication.push.PushManagerImpl
 

H

hashCode() - Method in class io.confluent.kafka.replication.push.ReplicationStateMetadata
 
highWatermark() - Method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent.RecordsPayload
 

I

info(ReplicationModeChangeLogger.ReplicationLogContext, String) - Static method in class io.confluent.kafka.replication.push.ReplicationModeChangeLogger
 
initCount(K, int) - Method in class io.confluent.kafka.replication.push.buffer.RefCountingMemoryTracker
Starts tracking the given ref-counted memory-occupying object.
INITIAL - Static variable in class io.confluent.kafka.replication.push.ReplicationStateMetadata
 
INITIAL_REPLICATION_SESSION_ID - Static variable in class io.confluent.kafka.replication.push.ReplicationStateMetadata
The initial replication session ID.
io.confluent.kafka.replication.push - package io.confluent.kafka.replication.push
 
io.confluent.kafka.replication.push.buffer - package io.confluent.kafka.replication.push.buffer
 
isActive() - Method in interface io.confluent.kafka.replication.push.PushManager
 
isActive() - Method in class io.confluent.kafka.replication.push.PushManagerImpl
 
isRequestReady() - Method in class io.confluent.kafka.replication.push.buffer.BufferingAppendRecordsBuilder
Return whether the request is ready to send.
isValidReplicationSessionId(long) - Static method in class io.confluent.kafka.replication.push.ReplicationStateMetadata
 

L

leaderEpoch() - Method in class io.confluent.kafka.replication.push.PushSession
 
LINGER_MS_DEFAULT - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
LINGER_MS_DOC - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
LINGER_MS_PROP - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
lingerMs() - Method in class io.confluent.kafka.replication.push.ReplicationConfig
 

M

MAX_IN_FLIGHT_REQUESTS_DEFAULT - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_IN_FLIGHT_REQUESTS_DOC - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_IN_FLIGHT_REQUESTS_PROP - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_MEMORY_BUFFER_BYTES_DEFAULT - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_MEMORY_BUFFER_BYTES_DOC - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_MEMORY_BUFFER_BYTES_PROP - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_PUSHERS_DEFAULT - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_PUSHERS_DOC - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_PUSHERS_PROP - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_REQUEST_PARTITION_SIZE_BYTES_DEFAULT - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_REQUEST_PARTITION_SIZE_BYTES_DOC - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_REQUEST_PARTITION_SIZE_BYTES_PROP - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_REQUEST_SIZE_BYTES_DEFAULT - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_REQUEST_SIZE_BYTES_DOC - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_REQUEST_SIZE_BYTES_PROP - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_WAIT_MS_DEFAULT - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_WAIT_MS_DOC - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
MAX_WAIT_MS_PROP - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
maxInFlightRequests() - Method in class io.confluent.kafka.replication.push.ReplicationConfig
 
maxMemoryBufferBytes() - Method in class io.confluent.kafka.replication.push.ReplicationConfig
 
maxPushers() - Method in class io.confluent.kafka.replication.push.ReplicationConfig
 
maxRequestPartitionSizeBytes() - Method in class io.confluent.kafka.replication.push.ReplicationConfig
 
maxRequestSizeBytes() - Method in class io.confluent.kafka.replication.push.ReplicationConfig
 
maxWaitMs() - Method in class io.confluent.kafka.replication.push.ReplicationConfig
 
memoryRecords() - Method in class io.confluent.kafka.replication.push.buffer.BufferingPartitionDataBuilder.PartitionRecords
 
mode() - Method in interface io.confluent.kafka.replication.push.ReplicationState
The replication mode of this partition replica.
mode() - Method in class io.confluent.kafka.replication.push.ReplicationStateMetadata
 

N

nextId(ReplicationState.Mode) - Method in class io.confluent.kafka.replication.push.ReplicationStateMetadata
 
nextReplicationState(ReplicationState.Mode, long) - Method in class io.confluent.kafka.replication.push.ReplicationStateMetadata
Follower replication mode transition proposal require the proposed session ID to be incremented when the leader requests a transition back to PULL.

O

offset() - Method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent.OffsetPayload
 
OffsetPayload(long) - Constructor for class io.confluent.kafka.replication.push.buffer.PushReplicationEvent.OffsetPayload
 
onAppendRecordsResponse(long, long) - Method in class io.confluent.kafka.replication.push.PushSession
Called on a successful AppendRecords response for that partition replica.
onHighWatermarkUpdate(TopicIdPartition, int, long) - Method in interface io.confluent.kafka.replication.push.Pusher
Should be called whenever the high watermark for a push-replicated partition replica is updated.
onHighWatermarkUpdate(TopicIdPartition, Set<Integer>, long) - Method in interface io.confluent.kafka.replication.push.PushManager
Invoked every time the high watermark of the given partition is updated.
onHighWatermarkUpdate(TopicIdPartition, Set<Integer>, long) - Method in class io.confluent.kafka.replication.push.PushManagerImpl
 
onLeaderAppend(TopicIdPartition, int, long, long, AbstractRecords) - Method in interface io.confluent.kafka.replication.push.Pusher
Buffers the given records to be replicated with some subsequent AppendRecords request.
onLeaderAppend(TopicIdPartition, Set<Integer>, long, long, AbstractRecords) - Method in interface io.confluent.kafka.replication.push.PushManager
Invoked every time this broker as the leader of the given partition appends memory records to its log (if the corresponding partition replica has transitioned to push replication), as well as the first time after starting a push session with the FileRecords needed to have the follower catch up to the leader.
onLeaderAppend(TopicIdPartition, Set<Integer>, long, long, AbstractRecords) - Method in class io.confluent.kafka.replication.push.PushManagerImpl
 
onLogStartOffsetUpdate(TopicIdPartition, int, long) - Method in interface io.confluent.kafka.replication.push.Pusher
Should be called whenever the log start offset for a push-replicated partition replica is updated.
onLogStartOffsetUpdate(TopicIdPartition, Set<Integer>, long) - Method in interface io.confluent.kafka.replication.push.PushManager
Invoked every time the log start offset of the given partition is updated.
onLogStartOffsetUpdate(TopicIdPartition, Set<Integer>, long) - Method in class io.confluent.kafka.replication.push.PushManagerImpl
 
onPushSessionEnded() - Method in class io.confluent.kafka.replication.push.PushSession
Called on an unsuccessful AppendRecords response or any other reason for stopping the active push replication session for that partition replica.

P

PartitionRecords(List<MemoryRecords>) - Constructor for class io.confluent.kafka.replication.push.buffer.BufferingPartitionDataBuilder.PartitionRecords
 
payload() - Method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent
The payload carried by this push replication event.
processEvent(PushReplicationEvent<?>, PushSession) - Method in class io.confluent.kafka.replication.push.buffer.BufferingAppendRecordsBuilder
Processes the given push replication event indicating whether it was successfully consumed in the returned boolean result.
PUSH_REPLICATION_FEATURE_ENABLE_DEFAULT - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
PUSH_REPLICATION_FEATURE_ENABLE_DOC - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
PUSH_REPLICATION_FEATURE_ENABLE_PROP - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
Pusher - Interface in io.confluent.kafka.replication.push
Used for proactively replicating (pushing) records for partitions led by this broker to its follower brokers.
PushManager - Interface in io.confluent.kafka.replication.push
Manages the buffering, tracking and pushing of records written to partition replicas that should be replicated via push replication.
PushManagerImpl - Class in io.confluent.kafka.replication.push
 
PushManagerImpl(ReplicationConfig, Time, Metrics, Function<Integer, Optional<Node>>, Function<Integer, NetworkClient>) - Constructor for class io.confluent.kafka.replication.push.PushManagerImpl
 
PushReplicationEvent<T> - Class in io.confluent.kafka.replication.push.buffer
A generic event representing a partition replica change that should be processed for the purposes of push replication.
PushReplicationEvent.OffsetPayload - Class in io.confluent.kafka.replication.push.buffer
A payload carrying a single offset value.
PushReplicationEvent.RecordsPayload - Class in io.confluent.kafka.replication.push.buffer
A payload carrying an AbstractRecords representing some records already appended on the partition replica leader, their append offset, and the high watermark value at the time of creating the records.
PushReplicationEvent.TransitionRecordsPayload - Class in io.confluent.kafka.replication.push.buffer
 
PushReplicationEvent.Type - Enum in io.confluent.kafka.replication.push.buffer
Enumerates the different types of push replication events.
pushReplicationModeEnabled(ReplicationConfig.Mode) - Static method in class io.confluent.kafka.replication.push.ReplicationConfig
 
PushSession - Class in io.confluent.kafka.replication.push
Identifies a push replication session for some partition replica.
PushSession(int, long, long) - Constructor for class io.confluent.kafka.replication.push.PushSession
 

R

records() - Method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent.RecordsPayload
 
RecordsPayload(AbstractRecords, long, long) - Constructor for class io.confluent.kafka.replication.push.buffer.PushReplicationEvent.RecordsPayload
 
RefCountingMemoryTracker<K> - Class in io.confluent.kafka.replication.push.buffer
A tracker that allows calculating the total memory taken by the ref-counted objects it tracks.
RefCountingMemoryTracker(Function<K, Integer>, long, Consumer<RemovalNotification<K, AtomicInteger>>) - Constructor for class io.confluent.kafka.replication.push.buffer.RefCountingMemoryTracker
 
release() - Method in class io.confluent.kafka.replication.push.buffer.BufferingPartitionDataBuilder.PartitionRecords
 
replicaEpoch() - Method in class io.confluent.kafka.replication.push.PushSession
 
replicaId() - Method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent
 
REPLICATION_MODE_DEFAULT - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
REPLICATION_MODE_DOC - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
REPLICATION_MODE_PROP - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
ReplicationConfig - Class in io.confluent.kafka.replication.push
 
ReplicationConfig(Map<?, ?>) - Constructor for class io.confluent.kafka.replication.push.ReplicationConfig
 
ReplicationConfig.Mode - Enum in io.confluent.kafka.replication.push
Enumerates the valid values for the ReplicationConfig.REPLICATION_MODE_PROP config property.
ReplicationLogContext(TopicIdPartition, int, long, int, long) - Constructor for class io.confluent.kafka.replication.push.ReplicationModeChangeLogger.ReplicationLogContext
 
replicationMode() - Method in class io.confluent.kafka.replication.push.ReplicationConfig
 
ReplicationModeChangeLogger - Class in io.confluent.kafka.replication.push
 
ReplicationModeChangeLogger() - Constructor for class io.confluent.kafka.replication.push.ReplicationModeChangeLogger
 
ReplicationModeChangeLogger.ReplicationLogContext - Class in io.confluent.kafka.replication.push
 
replicationSessionId() - Method in class io.confluent.kafka.replication.push.PushSession
 
replicationSessionId() - Method in interface io.confluent.kafka.replication.push.ReplicationState
The current replication session ID for this partition replica.
replicationSessionId() - Method in class io.confluent.kafka.replication.push.ReplicationStateMetadata
 
ReplicationState - Interface in io.confluent.kafka.replication.push
The per-partition-replica state maintained for push replication.
ReplicationState.Mode - Enum in io.confluent.kafka.replication.push
The different replication modes in which a partition replica can be in.
ReplicationStateMetadata - Class in io.confluent.kafka.replication.push
Manages replication mode transitions for push replication.
ReplicationStateMetadata(ReplicationState.Mode, long) - Constructor for class io.confluent.kafka.replication.push.ReplicationStateMetadata
 
REQUEST_TIMEOUT_MS_DEFAULT - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
REQUEST_TIMEOUT_MS_PROP - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
requestTimeoutMs() - Method in class io.confluent.kafka.replication.push.ReplicationConfig
 
RETRY_TIMEOUT_MS_DEFAULT - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
RETRY_TIMEOUT_MS_DOC - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
RETRY_TIMEOUT_MS_PROP - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
retryTimeoutMs() - Method in class io.confluent.kafka.replication.push.ReplicationConfig
 

S

shutdown() - Method in interface io.confluent.kafka.replication.push.Pusher
Shuts this pusher down, terminating all its push replication processing.
shutdown() - Method in interface io.confluent.kafka.replication.push.PushManager
Shuts down the manager, cleaning up any used resources (buffered records, initialized pusher threads, etc.).
shutdown() - Method in class io.confluent.kafka.replication.push.PushManagerImpl
 
sizeInBytes() - Method in class io.confluent.kafka.replication.push.buffer.BufferingPartitionDataBuilder.PartitionRecords
 
SOCKET_SEND_BUFFER_BYTES_DEFAULT - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
SOCKET_SEND_BUFFER_BYTES_DOC - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
SOCKET_SEND_BUFFER_BYTES_PROP - Static variable in class io.confluent.kafka.replication.push.ReplicationConfig
 
socketSendBufferBytes() - Method in class io.confluent.kafka.replication.push.ReplicationConfig
 
start() - Method in interface io.confluent.kafka.replication.push.Pusher
Starts the pusher thread.
startFuture() - Method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent.TransitionRecordsPayload
 
startFuture() - Method in class io.confluent.kafka.replication.push.PushSession
 
startPush(TopicIdPartition, int, PushSession) - Method in interface io.confluent.kafka.replication.push.Pusher
Adds this partition replica with its push replication session metadata to the set of partitions for which this pusher will be sending AppendRecords requests.
startPush(TopicIdPartition, int, PushSession) - Method in interface io.confluent.kafka.replication.push.PushManager
Initiates push replication for the given partition replica with the given replication session identifiers (leader epoch + replica epoch + replication session ID).
startPush(TopicIdPartition, int, PushSession) - Method in class io.confluent.kafka.replication.push.PushManagerImpl
 
startup() - Method in interface io.confluent.kafka.replication.push.PushManager
Starts up the push manager, including the pusher threads.
startup() - Method in class io.confluent.kafka.replication.push.PushManagerImpl
 
stopPush(TopicIdPartition, int, boolean) - Method in interface io.confluent.kafka.replication.push.Pusher
Stops the push replication session for the given partition, optionally preparing an AppendRecords request signaling the stoppage.
stopPush(TopicIdPartition, Set<Integer>, boolean) - Method in interface io.confluent.kafka.replication.push.PushManager
Stops push replication for the given partition replicas.
stopPush(TopicIdPartition, Set<Integer>, boolean) - Method in class io.confluent.kafka.replication.push.PushManagerImpl
 
stopPushAndDiscardState(PushReplicationEvent<CompletableFuture<Void>>) - Method in class io.confluent.kafka.replication.push.buffer.BufferingPartitionDataBuilder
Consumes a PushReplicationEvent.Type.STOP_PUSH event for this partition replica.
stringValues() - Static method in enum io.confluent.kafka.replication.push.ReplicationConfig.Mode
 

T

topicIdPartition() - Method in class io.confluent.kafka.replication.push.buffer.BufferingPartitionDataBuilder
 
topicIdPartition() - Method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent
 
toString() - Method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent.OffsetPayload
 
toString() - Method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent.RecordsPayload
 
toString() - Method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent
 
toString() - Method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent.TransitionRecordsPayload
 
toString() - Method in class io.confluent.kafka.replication.push.PushSession
 
toString() - Method in class io.confluent.kafka.replication.push.ReplicationModeChangeLogger.ReplicationLogContext
 
toString() - Method in class io.confluent.kafka.replication.push.ReplicationStateMetadata
 
totalBytes() - Method in class io.confluent.kafka.replication.push.buffer.RefCountingMemoryTracker
 
TransitionRecordsPayload(PushReplicationEvent.RecordsPayload, CompletableFuture<Void>) - Constructor for class io.confluent.kafka.replication.push.buffer.PushReplicationEvent.TransitionRecordsPayload
 
type() - Method in class io.confluent.kafka.replication.push.buffer.PushReplicationEvent
The type of this push replication event.

U

UNKNOWN_REPLICATION_SESSION_ID - Static variable in class io.confluent.kafka.replication.push.ReplicationStateMetadata
An invalid replication session ID.
UNSET_OFFSET_VALUE - Static variable in class io.confluent.kafka.replication.push.buffer.BufferingPartitionDataBuilder
 

V

validPreviousModes() - Method in enum io.confluent.kafka.replication.push.ReplicationState.Mode
 
valueOf(String) - Static method in enum io.confluent.kafka.replication.push.buffer.PushReplicationEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.kafka.replication.push.ReplicationConfig.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.kafka.replication.push.ReplicationState.Mode
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.confluent.kafka.replication.push.buffer.PushReplicationEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.confluent.kafka.replication.push.ReplicationConfig.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.confluent.kafka.replication.push.ReplicationState.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
A B C D E F G H I L M N O P R S T U V 
Skip navigation links